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."); + + /// + /// + /// + 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 implementation public partial class AlterUserScramCredentialsOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterUserScramCredentialsResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterUserScramCredentialsResult.cs index dde9f3829..c446e319d 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterUserScramCredentialsResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterUserScramCredentialsResult.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 AlterUserScramCredentialsResult + #region AlterUserScramCredentialsResult declaration + /// + /// + /// + 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 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 AlterUserScramCredentialsResult implementation public partial class AlterUserScramCredentialsResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/Config.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/Config.cs index 4be8cefa9..dbbff412c 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/Config.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/Config.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 Config + #region Config declaration + /// + /// + /// + 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 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 Config implementation public partial class Config { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ConfigEntry.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ConfigEntry.cs index 71722a841..0a06d7da4 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ConfigEntry.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ConfigEntry.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,187 @@ namespace Org.Apache.Kafka.Clients.Admin { - #region ConfigEntry + #region ConfigEntry declaration + /// + /// + /// + 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 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 ConfigSource declaration + /// + /// + /// + 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 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 ConfigSynonym declaration + /// + /// + /// + 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 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 ConfigType declaration + /// + /// + /// + 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 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 ConfigEntry implementation public partial class ConfigEntry { #region Constructors @@ -145,7 +325,7 @@ public Org.Apache.Kafka.Clients.Admin.ConfigEntry.ConfigType Type() #endregion #region Nested classes - #region ConfigSource + #region ConfigSource implementation public partial class ConfigSource { #region Constructors @@ -235,7 +415,7 @@ public static Org.Apache.Kafka.Clients.Admin.ConfigEntry.ConfigSource[] Values() } #endregion - #region ConfigSynonym + #region ConfigSynonym implementation public partial class ConfigSynonym { #region Constructors @@ -290,7 +470,7 @@ public Org.Apache.Kafka.Clients.Admin.ConfigEntry.ConfigSource Source() } #endregion - #region ConfigType + #region ConfigType implementation public partial class ConfigType { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ConsumerGroupDescription.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ConsumerGroupDescription.cs index 774b7cb5b..4023a0b50 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ConsumerGroupDescription.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ConsumerGroupDescription.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 ConsumerGroupDescription + #region ConsumerGroupDescription declaration + /// + /// + /// + 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 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 ConsumerGroupDescription implementation public partial class ConsumerGroupDescription { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ConsumerGroupListing.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ConsumerGroupListing.cs index 009462610..bb0eb61b7 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ConsumerGroupListing.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ConsumerGroupListing.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 ConsumerGroupListing + #region ConsumerGroupListing declaration + /// + /// + /// + 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 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 ConsumerGroupListing implementation public partial class ConsumerGroupListing { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreateAclsOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreateAclsOptions.cs index f04ab633e..5cdd75a75 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreateAclsOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreateAclsOptions.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 CreateAclsOptions + #region CreateAclsOptions declaration + /// + /// + /// + 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 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 CreateAclsOptions implementation public partial class CreateAclsOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreateAclsResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreateAclsResult.cs index 25a70eb34..e92940c7e 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreateAclsResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreateAclsResult.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 CreateAclsResult + #region CreateAclsResult declaration + /// + /// + /// + 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 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 CreateAclsResult implementation public partial class CreateAclsResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreateDelegationTokenOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreateDelegationTokenOptions.cs index bb568b1fb..1b266b82a 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreateDelegationTokenOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreateDelegationTokenOptions.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 CreateDelegationTokenOptions + #region CreateDelegationTokenOptions declaration + /// + /// + /// + 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 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 CreateDelegationTokenOptions implementation public partial class CreateDelegationTokenOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreateDelegationTokenResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreateDelegationTokenResult.cs index 779bc6932..c41d3fd3e 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreateDelegationTokenResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreateDelegationTokenResult.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 CreateDelegationTokenResult + #region CreateDelegationTokenResult declaration + /// + /// + /// + 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 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 CreateDelegationTokenResult implementation public partial class CreateDelegationTokenResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreatePartitionsOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreatePartitionsOptions.cs index 8b6ae50c6..3b8cd358d 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreatePartitionsOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreatePartitionsOptions.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 CreatePartitionsOptions + #region CreatePartitionsOptions declaration + /// + /// + /// + 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 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 CreatePartitionsOptions implementation public partial class CreatePartitionsOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreatePartitionsResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreatePartitionsResult.cs index 9ca3410fd..b6952ee40 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreatePartitionsResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreatePartitionsResult.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 CreatePartitionsResult + #region CreatePartitionsResult declaration + /// + /// + /// + 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 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 CreatePartitionsResult implementation public partial class CreatePartitionsResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreateTopicsOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreateTopicsOptions.cs index 0b4126c6a..8f19504de 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreateTopicsOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreateTopicsOptions.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 CreateTopicsOptions + #region CreateTopicsOptions declaration + /// + /// + /// + 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 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 CreateTopicsOptions implementation public partial class CreateTopicsOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreateTopicsResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreateTopicsResult.cs index 602cc61cd..bc68a3707 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreateTopicsResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/CreateTopicsResult.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 CreateTopicsResult + #region CreateTopicsResult declaration + /// + /// + /// + 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 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 TopicMetadataAndConfig declaration + /// + /// + /// + 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 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 CreateTopicsResult implementation public partial class CreateTopicsResult { #region Constructors @@ -101,7 +191,7 @@ public partial class CreateTopicsResult #endregion #region Nested classes - #region TopicMetadataAndConfig + #region TopicMetadataAndConfig implementation public partial class TopicMetadataAndConfig { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteAclsOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteAclsOptions.cs index 86e75cc42..a7878847d 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteAclsOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteAclsOptions.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 DeleteAclsOptions + #region DeleteAclsOptions declaration + /// + /// + /// + 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 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 DeleteAclsOptions implementation public partial class DeleteAclsOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteAclsResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteAclsResult.cs index 56030c9a3..160128098 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteAclsResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteAclsResult.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,142 @@ namespace Org.Apache.Kafka.Clients.Admin { - #region DeleteAclsResult + #region DeleteAclsResult declaration + /// + /// + /// + 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 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 FilterResult declaration + /// + /// + /// + 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 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 FilterResults declaration + /// + /// + /// + 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 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 DeleteAclsResult implementation public partial class DeleteAclsResult { #region Constructors @@ -65,7 +200,7 @@ public partial class DeleteAclsResult #endregion #region Nested classes - #region FilterResult + #region FilterResult implementation public partial class FilterResult { #region Constructors @@ -112,7 +247,7 @@ public Org.Apache.Kafka.Common.Errors.ApiException Exception() } #endregion - #region FilterResults + #region FilterResults implementation public partial class FilterResults { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteConsumerGroupOffsetsOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteConsumerGroupOffsetsOptions.cs index a94b2a2ee..33073e65d 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteConsumerGroupOffsetsOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteConsumerGroupOffsetsOptions.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 DeleteConsumerGroupOffsetsOptions + #region DeleteConsumerGroupOffsetsOptions declaration + /// + /// + /// + 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 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 DeleteConsumerGroupOffsetsOptions implementation public partial class DeleteConsumerGroupOffsetsOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteConsumerGroupOffsetsResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteConsumerGroupOffsetsResult.cs index 4c2f42cb5..727c6a7db 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteConsumerGroupOffsetsResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteConsumerGroupOffsetsResult.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 DeleteConsumerGroupOffsetsResult + #region DeleteConsumerGroupOffsetsResult declaration + /// + /// + /// + 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 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 DeleteConsumerGroupOffsetsResult implementation public partial class DeleteConsumerGroupOffsetsResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteConsumerGroupsOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteConsumerGroupsOptions.cs index 51c5c7923..6c5680b45 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteConsumerGroupsOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteConsumerGroupsOptions.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 DeleteConsumerGroupsOptions + #region DeleteConsumerGroupsOptions declaration + /// + /// + /// + 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 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 DeleteConsumerGroupsOptions implementation public partial class DeleteConsumerGroupsOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteConsumerGroupsResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteConsumerGroupsResult.cs index 2c03e434e..4b2a52700 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteConsumerGroupsResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteConsumerGroupsResult.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 DeleteConsumerGroupsResult + #region DeleteConsumerGroupsResult declaration + /// + /// + /// + 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 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 DeleteConsumerGroupsResult implementation public partial class DeleteConsumerGroupsResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteRecordsOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteRecordsOptions.cs index 27f5bc9c2..13664150e 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteRecordsOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteRecordsOptions.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 DeleteRecordsOptions + #region DeleteRecordsOptions declaration + /// + /// + /// + 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 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 DeleteRecordsOptions implementation public partial class DeleteRecordsOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteRecordsResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteRecordsResult.cs index 21462b34f..9805529a4 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteRecordsResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteRecordsResult.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 DeleteRecordsResult + #region DeleteRecordsResult declaration + /// + /// + /// + 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 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 DeleteRecordsResult implementation public partial class DeleteRecordsResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteTopicsOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteTopicsOptions.cs index 465fb2ebd..e155fab5b 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteTopicsOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteTopicsOptions.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 DeleteTopicsOptions + #region DeleteTopicsOptions declaration + /// + /// + /// + 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 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 DeleteTopicsOptions implementation public partial class DeleteTopicsOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteTopicsResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteTopicsResult.cs index dea5ae98a..364a620eb 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteTopicsResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeleteTopicsResult.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 DeleteTopicsResult + #region DeleteTopicsResult declaration + /// + /// + /// + 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 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 DeleteTopicsResult implementation public partial class DeleteTopicsResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeletedRecords.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeletedRecords.cs index fe76dfd44..fe4fead38 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeletedRecords.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DeletedRecords.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 DeletedRecords + #region DeletedRecords declaration + /// + /// + /// + 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 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 DeletedRecords implementation public partial class DeletedRecords { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeAclsOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeAclsOptions.cs index 7316348b6..3dc2760e9 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeAclsOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeAclsOptions.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 DescribeAclsOptions + #region DescribeAclsOptions declaration + /// + /// + /// + 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 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 DescribeAclsOptions implementation public partial class DescribeAclsOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeAclsResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeAclsResult.cs index 7d859d867..4b1d6f3cd 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeAclsResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeAclsResult.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 DescribeAclsResult + #region DescribeAclsResult declaration + /// + /// + /// + 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 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 DescribeAclsResult implementation public partial class DescribeAclsResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeClientQuotasOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeClientQuotasOptions.cs index 4917403a1..2ae8bc311 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeClientQuotasOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeClientQuotasOptions.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 DescribeClientQuotasOptions + #region DescribeClientQuotasOptions declaration + /// + /// + /// + 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 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 DescribeClientQuotasOptions implementation public partial class DescribeClientQuotasOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeClientQuotasResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeClientQuotasResult.cs index 1bb1369da..60b1ee23f 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeClientQuotasResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeClientQuotasResult.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 DescribeClientQuotasResult + #region DescribeClientQuotasResult declaration + /// + /// + /// + 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 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 DescribeClientQuotasResult implementation public partial class DescribeClientQuotasResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeClusterOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeClusterOptions.cs index 86e81c982..2f6da9624 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeClusterOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeClusterOptions.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 DescribeClusterOptions + #region DescribeClusterOptions declaration + /// + /// + /// + 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 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 DescribeClusterOptions implementation public partial class DescribeClusterOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeClusterResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeClusterResult.cs index 7769f2668..c2ae30402 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeClusterResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeClusterResult.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 DescribeClusterResult + #region DescribeClusterResult declaration + /// + /// + /// + 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 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 DescribeClusterResult implementation public partial class DescribeClusterResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeConfigsOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeConfigsOptions.cs index d1060b7b9..f58f7d0da 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeConfigsOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeConfigsOptions.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 DescribeConfigsOptions + #region DescribeConfigsOptions declaration + /// + /// + /// + 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 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 DescribeConfigsOptions implementation public partial class DescribeConfigsOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeConfigsResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeConfigsResult.cs index eb024dc60..e52db5f26 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeConfigsResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeConfigsResult.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 DescribeConfigsResult + #region DescribeConfigsResult declaration + /// + /// + /// + 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 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 DescribeConfigsResult implementation public partial class DescribeConfigsResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeConsumerGroupsOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeConsumerGroupsOptions.cs index 7bb828026..0375e540a 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeConsumerGroupsOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeConsumerGroupsOptions.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 DescribeConsumerGroupsOptions + #region DescribeConsumerGroupsOptions declaration + /// + /// + /// + 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 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 DescribeConsumerGroupsOptions implementation public partial class DescribeConsumerGroupsOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeConsumerGroupsResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeConsumerGroupsResult.cs index a38d54220..fd5e64bd2 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeConsumerGroupsResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeConsumerGroupsResult.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 DescribeConsumerGroupsResult + #region DescribeConsumerGroupsResult declaration + /// + /// + /// + 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 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 DescribeConsumerGroupsResult implementation public partial class DescribeConsumerGroupsResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeDelegationTokenOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeDelegationTokenOptions.cs index 1c5ba9487..77b796746 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeDelegationTokenOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeDelegationTokenOptions.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 DescribeDelegationTokenOptions + #region DescribeDelegationTokenOptions declaration + /// + /// + /// + 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 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 DescribeDelegationTokenOptions implementation public partial class DescribeDelegationTokenOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeDelegationTokenResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeDelegationTokenResult.cs index 7e6e9ee6a..6ad63f56f 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeDelegationTokenResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeDelegationTokenResult.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 DescribeDelegationTokenResult + #region DescribeDelegationTokenResult declaration + /// + /// + /// + 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 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 DescribeDelegationTokenResult implementation public partial class DescribeDelegationTokenResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeFeaturesOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeFeaturesOptions.cs index 9dba742c2..32e3e6ce8 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeFeaturesOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeFeaturesOptions.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 DescribeFeaturesOptions + #region DescribeFeaturesOptions declaration + /// + /// + /// + 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 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 DescribeFeaturesOptions implementation public partial class DescribeFeaturesOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeFeaturesResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeFeaturesResult.cs index 45cc97893..f030aa346 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeFeaturesResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeFeaturesResult.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 DescribeFeaturesResult + #region DescribeFeaturesResult declaration + /// + /// + /// + 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 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 DescribeFeaturesResult implementation public partial class DescribeFeaturesResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeLogDirsOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeLogDirsOptions.cs index b0ab85bdb..1dd472150 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeLogDirsOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeLogDirsOptions.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 DescribeLogDirsOptions + #region DescribeLogDirsOptions declaration + /// + /// + /// + 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 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 DescribeLogDirsOptions implementation public partial class DescribeLogDirsOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeLogDirsResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeLogDirsResult.cs index 6e44a24c9..acc9947e5 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeLogDirsResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeLogDirsResult.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 DescribeLogDirsResult + #region DescribeLogDirsResult declaration + /// + /// + /// + 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 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 DescribeLogDirsResult implementation public partial class DescribeLogDirsResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeMetadataQuorumOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeMetadataQuorumOptions.cs index b554673d3..65c9252e6 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeMetadataQuorumOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeMetadataQuorumOptions.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 DescribeMetadataQuorumOptions + #region DescribeMetadataQuorumOptions declaration + /// + /// + /// + 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 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 DescribeMetadataQuorumOptions implementation public partial class DescribeMetadataQuorumOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeMetadataQuorumResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeMetadataQuorumResult.cs index b2150a971..42e8fd37f 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeMetadataQuorumResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeMetadataQuorumResult.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 DescribeMetadataQuorumResult + #region DescribeMetadataQuorumResult declaration + /// + /// + /// + 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 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 DescribeMetadataQuorumResult implementation public partial class DescribeMetadataQuorumResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeProducersOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeProducersOptions.cs index 1ae63e2b5..0adf0b219 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeProducersOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeProducersOptions.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 DescribeProducersOptions + #region DescribeProducersOptions declaration + /// + /// + /// + 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 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 DescribeProducersOptions implementation public partial class DescribeProducersOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeProducersResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeProducersResult.cs index 8c04a56be..f33a13f27 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeProducersResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeProducersResult.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 DescribeProducersResult + #region DescribeProducersResult declaration + /// + /// + /// + 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 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 PartitionProducerState declaration + /// + /// + /// + 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 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 DescribeProducersResult implementation public partial class DescribeProducersResult { #region Constructors @@ -66,7 +156,7 @@ public partial class DescribeProducersResult #endregion #region Nested classes - #region PartitionProducerState + #region PartitionProducerState implementation public partial class PartitionProducerState { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeReplicaLogDirsOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeReplicaLogDirsOptions.cs index 8cd0abb39..17ecd6b9c 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeReplicaLogDirsOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeReplicaLogDirsOptions.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 DescribeReplicaLogDirsOptions + #region DescribeReplicaLogDirsOptions declaration + /// + /// + /// + 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 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 DescribeReplicaLogDirsOptions implementation public partial class DescribeReplicaLogDirsOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeReplicaLogDirsResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeReplicaLogDirsResult.cs index 8f83ac2ba..90531dc38 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeReplicaLogDirsResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeReplicaLogDirsResult.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 DescribeReplicaLogDirsResult + #region DescribeReplicaLogDirsResult declaration + /// + /// + /// + 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 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 ReplicaLogDirInfo declaration + /// + /// + /// + 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 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 DescribeReplicaLogDirsResult implementation public partial class DescribeReplicaLogDirsResult { #region Constructors @@ -65,7 +155,7 @@ public partial class DescribeReplicaLogDirsResult #endregion #region Nested classes - #region ReplicaLogDirInfo + #region ReplicaLogDirInfo implementation public partial class ReplicaLogDirInfo { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeTopicsOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeTopicsOptions.cs index cc8ccb3bc..0da2ff2d0 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeTopicsOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeTopicsOptions.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 DescribeTopicsOptions + #region DescribeTopicsOptions declaration + /// + /// + /// + 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 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 DescribeTopicsOptions implementation public partial class DescribeTopicsOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeTopicsResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeTopicsResult.cs index a54a55f47..13e8c78c9 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeTopicsResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeTopicsResult.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 DescribeTopicsResult + #region DescribeTopicsResult declaration + /// + /// + /// + 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 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 DescribeTopicsResult implementation public partial class DescribeTopicsResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeTransactionsOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeTransactionsOptions.cs index 12f67579c..329b960dd 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeTransactionsOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeTransactionsOptions.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 DescribeTransactionsOptions + #region DescribeTransactionsOptions declaration + /// + /// + /// + 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 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 DescribeTransactionsOptions implementation public partial class DescribeTransactionsOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeTransactionsResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeTransactionsResult.cs index 56c8b0be8..92f78d4d9 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeTransactionsResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeTransactionsResult.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 DescribeTransactionsResult + #region DescribeTransactionsResult declaration + /// + /// + /// + 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 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 DescribeTransactionsResult implementation public partial class DescribeTransactionsResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeUserScramCredentialsOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeUserScramCredentialsOptions.cs index 841c3c7a4..6368d9c40 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeUserScramCredentialsOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeUserScramCredentialsOptions.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 DescribeUserScramCredentialsOptions + #region DescribeUserScramCredentialsOptions declaration + /// + /// + /// + 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 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 DescribeUserScramCredentialsOptions implementation public partial class DescribeUserScramCredentialsOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeUserScramCredentialsResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeUserScramCredentialsResult.cs index 5acd8c890..cbef56a6b 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeUserScramCredentialsResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/DescribeUserScramCredentialsResult.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 DescribeUserScramCredentialsResult + #region DescribeUserScramCredentialsResult declaration + /// + /// + /// + 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 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 DescribeUserScramCredentialsResult implementation public partial class DescribeUserScramCredentialsResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ElectLeadersOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ElectLeadersOptions.cs index 32ac2786a..315fd8350 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ElectLeadersOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ElectLeadersOptions.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 ElectLeadersOptions + #region ElectLeadersOptions declaration + /// + /// + /// + 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 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 ElectLeadersOptions implementation public partial class ElectLeadersOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ElectLeadersResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ElectLeadersResult.cs index 5c0b96144..4174f78c2 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ElectLeadersResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ElectLeadersResult.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 ElectLeadersResult + #region ElectLeadersResult declaration + /// + /// + /// + 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 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 ElectLeadersResult implementation public partial class ElectLeadersResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ExpireDelegationTokenOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ExpireDelegationTokenOptions.cs index cc27c9058..ad0e0c39c 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ExpireDelegationTokenOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ExpireDelegationTokenOptions.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 ExpireDelegationTokenOptions + #region ExpireDelegationTokenOptions declaration + /// + /// + /// + 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 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 ExpireDelegationTokenOptions implementation public partial class ExpireDelegationTokenOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ExpireDelegationTokenResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ExpireDelegationTokenResult.cs index 37ebf4f39..daa3269a1 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ExpireDelegationTokenResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ExpireDelegationTokenResult.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 ExpireDelegationTokenResult + #region ExpireDelegationTokenResult declaration + /// + /// + /// + 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 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 ExpireDelegationTokenResult implementation public partial class ExpireDelegationTokenResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/FeatureMetadata.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/FeatureMetadata.cs index b1b9a6e4a..9b312cb24 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/FeatureMetadata.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/FeatureMetadata.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 FeatureMetadata + #region FeatureMetadata declaration + /// + /// + /// + 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 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 FeatureMetadata implementation public partial class FeatureMetadata { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/FeatureUpdate.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/FeatureUpdate.cs index 7017c4bab..969782912 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/FeatureUpdate.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/FeatureUpdate.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 FeatureUpdate + #region FeatureUpdate declaration + /// + /// + /// + 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 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 UpgradeType declaration + /// + /// + /// + 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 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 FeatureUpdate implementation public partial class FeatureUpdate { #region Constructors @@ -74,7 +164,7 @@ public short MaxVersionLevel() #endregion #region Nested classes - #region UpgradeType + #region UpgradeType implementation public partial class UpgradeType { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/FenceProducersOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/FenceProducersOptions.cs index b5186edf1..d49071f2d 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/FenceProducersOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/FenceProducersOptions.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 FenceProducersOptions + #region FenceProducersOptions declaration + /// + /// + /// + 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 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 FenceProducersOptions implementation public partial class FenceProducersOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/FenceProducersResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/FenceProducersResult.cs index 7dc35d3a2..72cd371d2 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/FenceProducersResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/FenceProducersResult.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 FenceProducersResult + #region FenceProducersResult declaration + /// + /// + /// + 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 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 FenceProducersResult implementation public partial class FenceProducersResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/FinalizedVersionRange.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/FinalizedVersionRange.cs index 445e2fc0b..957eb7e87 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/FinalizedVersionRange.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/FinalizedVersionRange.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 FinalizedVersionRange + #region FinalizedVersionRange declaration + /// + /// + /// + 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 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 FinalizedVersionRange implementation public partial class FinalizedVersionRange { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ForwardingAdmin.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ForwardingAdmin.cs index 4a6fbbc07..19d25649d 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ForwardingAdmin.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ForwardingAdmin.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 ForwardingAdmin + #region ForwardingAdmin declaration + /// + /// + /// + 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 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 ForwardingAdmin implementation public partial class ForwardingAdmin { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/KafkaAdminClient.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/KafkaAdminClient.cs index 7bf6804c1..63a302e6e 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/KafkaAdminClient.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/KafkaAdminClient.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 KafkaAdminClient + #region KafkaAdminClient declaration + /// + /// + /// + 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 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 KafkaAdminClient implementation public partial class KafkaAdminClient { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListConsumerGroupOffsetsOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListConsumerGroupOffsetsOptions.cs index 7b241d218..7fc56d71e 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListConsumerGroupOffsetsOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListConsumerGroupOffsetsOptions.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 ListConsumerGroupOffsetsOptions + #region ListConsumerGroupOffsetsOptions declaration + /// + /// + /// + 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 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 ListConsumerGroupOffsetsOptions implementation public partial class ListConsumerGroupOffsetsOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListConsumerGroupOffsetsResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListConsumerGroupOffsetsResult.cs index f0d375724..79c0aec67 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListConsumerGroupOffsetsResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListConsumerGroupOffsetsResult.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 ListConsumerGroupOffsetsResult + #region ListConsumerGroupOffsetsResult declaration + /// + /// + /// + 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 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 ListConsumerGroupOffsetsResult implementation public partial class ListConsumerGroupOffsetsResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListConsumerGroupOffsetsSpec.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListConsumerGroupOffsetsSpec.cs index 35e28cbeb..b5973b006 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListConsumerGroupOffsetsSpec.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListConsumerGroupOffsetsSpec.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 ListConsumerGroupOffsetsSpec + #region ListConsumerGroupOffsetsSpec declaration + /// + /// + /// + 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 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 ListConsumerGroupOffsetsSpec implementation public partial class ListConsumerGroupOffsetsSpec { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListConsumerGroupsOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListConsumerGroupsOptions.cs index 782d796d6..1efcd13b8 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListConsumerGroupsOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListConsumerGroupsOptions.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 ListConsumerGroupsOptions + #region ListConsumerGroupsOptions declaration + /// + /// + /// + 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 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 ListConsumerGroupsOptions implementation public partial class ListConsumerGroupsOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListConsumerGroupsResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListConsumerGroupsResult.cs index e2711b912..3f364343d 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListConsumerGroupsResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListConsumerGroupsResult.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 ListConsumerGroupsResult + #region ListConsumerGroupsResult declaration + /// + /// + /// + 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 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 ListConsumerGroupsResult implementation public partial class ListConsumerGroupsResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListOffsetsOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListOffsetsOptions.cs index 88a3c4740..91fa42e7b 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListOffsetsOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListOffsetsOptions.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 ListOffsetsOptions + #region ListOffsetsOptions declaration + /// + /// + /// + 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 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 ListOffsetsOptions implementation public partial class ListOffsetsOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListOffsetsResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListOffsetsResult.cs index e78c47389..f8e7a7276 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListOffsetsResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListOffsetsResult.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 ListOffsetsResult + #region ListOffsetsResult declaration + /// + /// + /// + 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 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 ListOffsetsResultInfo declaration + /// + /// + /// + 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 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 ListOffsetsResult implementation public partial class ListOffsetsResult { #region Constructors @@ -74,7 +164,7 @@ public ListOffsetsResult(Java.Util.Map + /// + /// + 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 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 ListPartitionReassignmentsOptions implementation public partial class ListPartitionReassignmentsOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListPartitionReassignmentsResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListPartitionReassignmentsResult.cs index 6edf895ca..da26a634f 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListPartitionReassignmentsResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListPartitionReassignmentsResult.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 ListPartitionReassignmentsResult + #region ListPartitionReassignmentsResult declaration + /// + /// + /// + 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 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 ListPartitionReassignmentsResult implementation public partial class ListPartitionReassignmentsResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListTopicsOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListTopicsOptions.cs index 7319a0122..58ac083be 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListTopicsOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListTopicsOptions.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 ListTopicsOptions + #region ListTopicsOptions declaration + /// + /// + /// + 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 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 ListTopicsOptions implementation public partial class ListTopicsOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListTopicsResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListTopicsResult.cs index 61560829d..b548c232d 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListTopicsResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListTopicsResult.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 ListTopicsResult + #region ListTopicsResult declaration + /// + /// + /// + 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 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 ListTopicsResult implementation public partial class ListTopicsResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListTransactionsOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListTransactionsOptions.cs index 7314ec0c3..ed889c905 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListTransactionsOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListTransactionsOptions.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 ListTransactionsOptions + #region ListTransactionsOptions declaration + /// + /// + /// + 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 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 ListTransactionsOptions implementation public partial class ListTransactionsOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListTransactionsResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListTransactionsResult.cs index 1ed751597..d6c255609 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListTransactionsResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ListTransactionsResult.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 ListTransactionsResult + #region ListTransactionsResult declaration + /// + /// + /// + 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 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 ListTransactionsResult implementation public partial class ListTransactionsResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/LogDirDescription.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/LogDirDescription.cs index 1b0c82270..326994925 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/LogDirDescription.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/LogDirDescription.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 LogDirDescription + #region LogDirDescription declaration + /// + /// + /// + 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 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 LogDirDescription implementation public partial class LogDirDescription { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/MemberAssignment.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/MemberAssignment.cs index b3715ff15..3356fc796 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/MemberAssignment.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/MemberAssignment.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 MemberAssignment + #region MemberAssignment declaration + /// + /// + /// + 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 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 MemberAssignment implementation public partial class MemberAssignment { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/MemberDescription.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/MemberDescription.cs index e06749ac0..2d3cc773e 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/MemberDescription.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/MemberDescription.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 MemberDescription + #region MemberDescription declaration + /// + /// + /// + 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 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 MemberDescription implementation public partial class MemberDescription { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/MemberToRemove.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/MemberToRemove.cs index ea47c4cb0..1a36135a0 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/MemberToRemove.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/MemberToRemove.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 MemberToRemove + #region MemberToRemove declaration + /// + /// + /// + 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 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 MemberToRemove implementation public partial class MemberToRemove { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/NewPartitionReassignment.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/NewPartitionReassignment.cs index 44fa7ab69..e561417fa 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/NewPartitionReassignment.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/NewPartitionReassignment.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 NewPartitionReassignment + #region NewPartitionReassignment declaration + /// + /// + /// + 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 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 NewPartitionReassignment implementation public partial class NewPartitionReassignment { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/NewPartitions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/NewPartitions.cs index a57dba6c0..b8a97b69a 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/NewPartitions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/NewPartitions.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 NewPartitions + #region NewPartitions declaration + /// + /// + /// + 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 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 NewPartitions implementation public partial class NewPartitions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/NewTopic.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/NewTopic.cs index e873a2067..cd446c686 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/NewTopic.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/NewTopic.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 NewTopic + #region NewTopic declaration + /// + /// + /// + 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 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 NewTopic implementation public partial class NewTopic { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/OffsetSpec.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/OffsetSpec.cs index 041806479..742134fa0 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/OffsetSpec.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/OffsetSpec.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,232 @@ namespace Org.Apache.Kafka.Clients.Admin { - #region OffsetSpec + #region OffsetSpec declaration + /// + /// + /// + 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 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 EarliestSpec declaration + /// + /// + /// + 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 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 LatestSpec declaration + /// + /// + /// + 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 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 MaxTimestampSpec declaration + /// + /// + /// + 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 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 TimestampSpec declaration + /// + /// + /// + 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 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 OffsetSpec implementation public partial class OffsetSpec { #region Constructors @@ -82,7 +307,7 @@ public static Org.Apache.Kafka.Clients.Admin.OffsetSpec MaxTimestamp() #endregion #region Nested classes - #region EarliestSpec + #region EarliestSpec implementation public partial class EarliestSpec { #region Constructors @@ -113,7 +338,7 @@ public partial class EarliestSpec } #endregion - #region LatestSpec + #region LatestSpec implementation public partial class LatestSpec { #region Constructors @@ -144,7 +369,7 @@ public partial class LatestSpec } #endregion - #region MaxTimestampSpec + #region MaxTimestampSpec implementation public partial class MaxTimestampSpec { #region Constructors @@ -175,7 +400,7 @@ public partial class MaxTimestampSpec } #endregion - #region TimestampSpec + #region TimestampSpec implementation public partial class TimestampSpec { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/PartitionReassignment.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/PartitionReassignment.cs index 42ba644b9..4a06157df 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/PartitionReassignment.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/PartitionReassignment.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 PartitionReassignment + #region PartitionReassignment declaration + /// + /// + /// + 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 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 PartitionReassignment implementation public partial class PartitionReassignment { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ProducerState.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ProducerState.cs index 2f743710d..936535a15 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ProducerState.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ProducerState.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 ProducerState + #region ProducerState declaration + /// + /// + /// + 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 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 ProducerState implementation public partial class ProducerState { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/QuorumInfo.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/QuorumInfo.cs index a49496381..09df08031 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/QuorumInfo.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/QuorumInfo.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 QuorumInfo + #region QuorumInfo declaration + /// + /// + /// + 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 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 ReplicaState declaration + /// + /// + /// + 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 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 QuorumInfo implementation public partial class QuorumInfo { #region Constructors @@ -89,7 +179,7 @@ public long LeaderEpoch() #endregion #region Nested classes - #region ReplicaState + #region ReplicaState implementation public partial class ReplicaState { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/RecordsToDelete.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/RecordsToDelete.cs index a5a2e6139..af539ab3a 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/RecordsToDelete.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/RecordsToDelete.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 RecordsToDelete + #region RecordsToDelete declaration + /// + /// + /// + 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 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 RecordsToDelete implementation public partial class RecordsToDelete { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/RemoveMembersFromConsumerGroupOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/RemoveMembersFromConsumerGroupOptions.cs index 0b519bb06..89475ff90 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/RemoveMembersFromConsumerGroupOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/RemoveMembersFromConsumerGroupOptions.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 RemoveMembersFromConsumerGroupOptions + #region RemoveMembersFromConsumerGroupOptions declaration + /// + /// + /// + 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 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 RemoveMembersFromConsumerGroupOptions implementation public partial class RemoveMembersFromConsumerGroupOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/RemoveMembersFromConsumerGroupResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/RemoveMembersFromConsumerGroupResult.cs index b6e41412e..d5186c68c 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/RemoveMembersFromConsumerGroupResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/RemoveMembersFromConsumerGroupResult.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 RemoveMembersFromConsumerGroupResult + #region RemoveMembersFromConsumerGroupResult declaration + /// + /// + /// + 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 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 RemoveMembersFromConsumerGroupResult implementation public partial class RemoveMembersFromConsumerGroupResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/RenewDelegationTokenOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/RenewDelegationTokenOptions.cs index 2c78df659..11f70f236 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/RenewDelegationTokenOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/RenewDelegationTokenOptions.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 RenewDelegationTokenOptions + #region RenewDelegationTokenOptions declaration + /// + /// + /// + 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 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 RenewDelegationTokenOptions implementation public partial class RenewDelegationTokenOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/RenewDelegationTokenResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/RenewDelegationTokenResult.cs index bab789f27..a86ceb019 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/RenewDelegationTokenResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/RenewDelegationTokenResult.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 RenewDelegationTokenResult + #region RenewDelegationTokenResult declaration + /// + /// + /// + 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 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 RenewDelegationTokenResult implementation public partial class RenewDelegationTokenResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ReplicaInfo.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ReplicaInfo.cs index 4fb8095d5..d07225d33 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ReplicaInfo.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ReplicaInfo.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 ReplicaInfo + #region ReplicaInfo declaration + /// + /// + /// + 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 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 ReplicaInfo implementation public partial class ReplicaInfo { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ScramCredentialInfo.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ScramCredentialInfo.cs index 219b0ad7e..aa0be84b1 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ScramCredentialInfo.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ScramCredentialInfo.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 ScramCredentialInfo + #region ScramCredentialInfo declaration + /// + /// + /// + 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 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 ScramCredentialInfo implementation public partial class ScramCredentialInfo { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ScramMechanism.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ScramMechanism.cs index 8162a88d8..18892b90e 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ScramMechanism.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/ScramMechanism.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 ScramMechanism + #region ScramMechanism declaration + /// + /// + /// + 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 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 ScramMechanism implementation public partial class ScramMechanism { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/SupportedVersionRange.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/SupportedVersionRange.cs index 815dccab5..7afc62ab3 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/SupportedVersionRange.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/SupportedVersionRange.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 SupportedVersionRange + #region SupportedVersionRange declaration + /// + /// + /// + 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 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 SupportedVersionRange implementation public partial class SupportedVersionRange { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/TopicDescription.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/TopicDescription.cs index a70f79688..e431f9882 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/TopicDescription.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/TopicDescription.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 TopicDescription + #region TopicDescription declaration + /// + /// + /// + 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 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 TopicDescription implementation public partial class TopicDescription { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/TopicListing.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/TopicListing.cs index 88bf96afc..74a321316 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/TopicListing.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/TopicListing.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 TopicListing + #region TopicListing declaration + /// + /// + /// + 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 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 TopicListing implementation public partial class TopicListing { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/TransactionDescription.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/TransactionDescription.cs index 1d61d71f3..f89083018 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/TransactionDescription.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/TransactionDescription.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 TransactionDescription + #region TransactionDescription declaration + /// + /// + /// + 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 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 TransactionDescription implementation public partial class TransactionDescription { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/TransactionListing.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/TransactionListing.cs index 6363915c4..4671a5b11 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/TransactionListing.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/TransactionListing.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 TransactionListing + #region TransactionListing declaration + /// + /// + /// + 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 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 TransactionListing implementation public partial class TransactionListing { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/TransactionState.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/TransactionState.cs index 00ae4a301..31f381c2b 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/TransactionState.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/TransactionState.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 TransactionState + #region TransactionState declaration + /// + /// + /// + 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 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 TransactionState implementation public partial class TransactionState { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UnregisterBrokerOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UnregisterBrokerOptions.cs index b35b08eda..253b85839 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UnregisterBrokerOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UnregisterBrokerOptions.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 UnregisterBrokerOptions + #region UnregisterBrokerOptions declaration + /// + /// + /// + 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 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 UnregisterBrokerOptions implementation public partial class UnregisterBrokerOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UnregisterBrokerResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UnregisterBrokerResult.cs index 39c78c436..c892910e9 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UnregisterBrokerResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UnregisterBrokerResult.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 UnregisterBrokerResult + #region UnregisterBrokerResult declaration + /// + /// + /// + 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 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 UnregisterBrokerResult implementation public partial class UnregisterBrokerResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UpdateFeaturesOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UpdateFeaturesOptions.cs index 108feaf11..3a3a88f6d 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UpdateFeaturesOptions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UpdateFeaturesOptions.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 UpdateFeaturesOptions + #region UpdateFeaturesOptions declaration + /// + /// + /// + 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 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 UpdateFeaturesOptions implementation public partial class UpdateFeaturesOptions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UpdateFeaturesResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UpdateFeaturesResult.cs index ee7aea177..4c9a4a6c3 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UpdateFeaturesResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UpdateFeaturesResult.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 UpdateFeaturesResult + #region UpdateFeaturesResult declaration + /// + /// + /// + 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 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 UpdateFeaturesResult implementation public partial class UpdateFeaturesResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UserScramCredentialAlteration.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UserScramCredentialAlteration.cs index a890b65b1..f0439ae00 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UserScramCredentialAlteration.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UserScramCredentialAlteration.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 UserScramCredentialAlteration + #region UserScramCredentialAlteration declaration + /// + /// + /// + 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 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 UserScramCredentialAlteration implementation public partial class UserScramCredentialAlteration { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UserScramCredentialDeletion.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UserScramCredentialDeletion.cs index 6ea2fa4b0..b4f2ecd64 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UserScramCredentialDeletion.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UserScramCredentialDeletion.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 UserScramCredentialDeletion + #region UserScramCredentialDeletion declaration + /// + /// + /// + 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 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 UserScramCredentialDeletion implementation public partial class UserScramCredentialDeletion { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UserScramCredentialUpsertion.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UserScramCredentialUpsertion.cs index 4d54efdee..23b8e644e 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UserScramCredentialUpsertion.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UserScramCredentialUpsertion.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 UserScramCredentialUpsertion + #region UserScramCredentialUpsertion declaration + /// + /// + /// + 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 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 UserScramCredentialUpsertion implementation public partial class UserScramCredentialUpsertion { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UserScramCredentialsDescription.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UserScramCredentialsDescription.cs index 85bdbd9e8..99fba3b9f 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UserScramCredentialsDescription.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/UserScramCredentialsDescription.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 UserScramCredentialsDescription + #region UserScramCredentialsDescription declaration + /// + /// + /// + 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 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 UserScramCredentialsDescription implementation public partial class UserScramCredentialsDescription { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/AllPackageClasses.cs deleted file mode 100644 index 4d8fc8c77..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/AllPackageClasses.cs +++ /dev/null @@ -1,909 +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 -{ - #region ApiVersions - /// - /// - /// - public partial class ApiVersions : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.clients.ApiVersions"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ApiVersions() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ApiVersions(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 ClientDnsLookup - /// - /// - /// - public partial class ClientDnsLookup : Java.Lang.Enum - { - const string _bridgeClassName = "org.apache.kafka.clients.ClientDnsLookup"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ClientDnsLookup() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ClientDnsLookup(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 ClientResponse - /// - /// - /// - public partial class ClientResponse : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.clients.ClientResponse"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ClientResponse() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ClientResponse(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 ClientUtils - /// - /// - /// - public partial class ClientUtils : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.clients.ClientUtils"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ClientUtils() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ClientUtils(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 CommonClientConfigs - /// - /// - /// - public partial class CommonClientConfigs : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.clients.CommonClientConfigs"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public CommonClientConfigs() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public CommonClientConfigs(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 ConnectionState - /// - /// - /// - public partial class ConnectionState : Java.Lang.Enum - { - const string _bridgeClassName = "org.apache.kafka.clients.ConnectionState"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ConnectionState() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ConnectionState(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 DefaultHostResolver - /// - /// - /// - public partial class DefaultHostResolver : Org.Apache.Kafka.Clients.HostResolver - { - const string _bridgeClassName = "org.apache.kafka.clients.DefaultHostResolver"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public DefaultHostResolver() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public DefaultHostResolver(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 GroupRebalanceConfig - /// - /// - /// - public partial class GroupRebalanceConfig : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.clients.GroupRebalanceConfig"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public GroupRebalanceConfig() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public GroupRebalanceConfig(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 ProtocolType - /// - /// - /// - public partial class ProtocolType : Java.Lang.Enum - { - const string _bridgeClassName = "org.apache.kafka.clients.GroupRebalanceConfig$ProtocolType"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ProtocolType() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ProtocolType(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 HostResolver - /// - /// - /// - public partial class HostResolver : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.clients.HostResolver"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("HostResolver 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 HostResolver() { } - /// - /// 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("HostResolver 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 HostResolver(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 ManualMetadataUpdater - /// - /// - /// - public partial class ManualMetadataUpdater : Org.Apache.Kafka.Clients.MetadataUpdater - { - const string _bridgeClassName = "org.apache.kafka.clients.ManualMetadataUpdater"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ManualMetadataUpdater() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ManualMetadataUpdater(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 Metadata - /// - /// - /// - public partial class Metadata : Java.Io.Closeable - { - const string _bridgeClassName = "org.apache.kafka.clients.Metadata"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Metadata() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Metadata(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 LeaderAndEpoch - /// - /// - /// - public partial class LeaderAndEpoch : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.clients.Metadata$LeaderAndEpoch"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public LeaderAndEpoch() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public LeaderAndEpoch(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 MetadataRequestAndVersion - /// - /// - /// - public partial class MetadataRequestAndVersion : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.clients.Metadata$MetadataRequestAndVersion"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public MetadataRequestAndVersion() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public MetadataRequestAndVersion(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 MetadataSnapshot - /// - /// - /// - public partial class MetadataSnapshot : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.clients.MetadataSnapshot"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public MetadataSnapshot() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public MetadataSnapshot(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 MetadataUpdater - /// - /// - /// - public partial class MetadataUpdater : Java.Io.Closeable - { - const string _bridgeClassName = "org.apache.kafka.clients.MetadataUpdater"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("MetadataUpdater 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 MetadataUpdater() { } - /// - /// 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("MetadataUpdater 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 MetadataUpdater(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 NetworkClientUtils - /// - /// - /// - public partial class NetworkClientUtils : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.clients.NetworkClientUtils"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public NetworkClientUtils() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public NetworkClientUtils(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 NodeApiVersions - /// - /// - /// - public partial class NodeApiVersions : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.clients.NodeApiVersions"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public NodeApiVersions() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public NodeApiVersions(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 RequestCompletionHandler - /// - /// - /// - public partial class RequestCompletionHandler : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.clients.RequestCompletionHandler"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("RequestCompletionHandler 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 RequestCompletionHandler() { } - /// - /// 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("RequestCompletionHandler 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 RequestCompletionHandler(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 StaleMetadataException - /// - /// - /// - public partial class StaleMetadataException : Org.Apache.Kafka.Common.Errors.InvalidMetadataException - { - const string _bridgeClassName = "org.apache.kafka.clients.StaleMetadataException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - - -} \ No newline at end of file diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/ApiVersions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/ApiVersions.cs index d8be21a6f..f708e65ae 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/ApiVersions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/ApiVersions.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 { - #region ApiVersions + #region ApiVersions declaration + /// + /// + /// + public partial class ApiVersions : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.clients.ApiVersions"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ApiVersions() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ApiVersions(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 ApiVersions implementation public partial class ApiVersions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/ClientDnsLookup.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/ClientDnsLookup.cs index 6711e6a41..697564f85 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/ClientDnsLookup.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/ClientDnsLookup.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 { - #region ClientDnsLookup + #region ClientDnsLookup declaration + /// + /// + /// + public partial class ClientDnsLookup : Java.Lang.Enum + { + const string _bridgeClassName = "org.apache.kafka.clients.ClientDnsLookup"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ClientDnsLookup() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ClientDnsLookup(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 ClientDnsLookup implementation public partial class ClientDnsLookup { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/ClientResponse.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/ClientResponse.cs index bb179aa2f..cb1988924 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/ClientResponse.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/ClientResponse.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 { - #region ClientResponse + #region ClientResponse declaration + /// + /// + /// + public partial class ClientResponse : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.clients.ClientResponse"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ClientResponse() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ClientResponse(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 ClientResponse implementation public partial class ClientResponse { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/ClientUtils.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/ClientUtils.cs index 9894e977c..f48e47a43 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/ClientUtils.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/ClientUtils.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 { - #region ClientUtils + #region ClientUtils declaration + /// + /// + /// + public partial class ClientUtils : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.clients.ClientUtils"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ClientUtils() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ClientUtils(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 ClientUtils implementation public partial class ClientUtils { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/CommonClientConfigs.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/CommonClientConfigs.cs index f699a7540..005e831d8 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/CommonClientConfigs.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/CommonClientConfigs.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 { - #region CommonClientConfigs + #region CommonClientConfigs declaration + /// + /// + /// + public partial class CommonClientConfigs : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.clients.CommonClientConfigs"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public CommonClientConfigs() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public CommonClientConfigs(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 CommonClientConfigs implementation public partial class CommonClientConfigs { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/ConnectionState.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/ConnectionState.cs index 063e3b264..2a28c425a 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/ConnectionState.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/ConnectionState.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 { - #region ConnectionState + #region ConnectionState declaration + /// + /// + /// + public partial class ConnectionState : Java.Lang.Enum + { + const string _bridgeClassName = "org.apache.kafka.clients.ConnectionState"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ConnectionState() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ConnectionState(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 ConnectionState implementation public partial class ConnectionState { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/AllPackageClasses.cs deleted file mode 100644 index 5be61fd68..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/AllPackageClasses.cs +++ /dev/null @@ -1,1564 +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.Consumer -{ - #region CommitFailedException - /// - /// - /// - public partial class CommitFailedException : Org.Apache.Kafka.Common.KafkaException - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.CommitFailedException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region Consumer - /// - /// - /// - public partial class Consumer : Java.Io.Closeable - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.Consumer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("Consumer 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 Consumer() { } - /// - /// 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("Consumer 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 Consumer(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 Consumer - /// - /// - /// - /// - /// - public partial class Consumer : Java.Io.Closeable - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.Consumer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("Consumer 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 Consumer() { } - /// - /// 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("Consumer 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 Consumer(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 ConsumerConfig - /// - /// - /// - public partial class ConsumerConfig : Org.Apache.Kafka.Common.Config.AbstractConfig, MASES.JCOBridge.C2JBridge.IJVMBridgeMain - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerConfig"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ConsumerConfig() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ConsumerConfig(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 ConsumerGroupMetadata - /// - /// - /// - public partial class ConsumerGroupMetadata : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerGroupMetadata"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ConsumerGroupMetadata() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ConsumerGroupMetadata(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 ConsumerInterceptor - /// - /// - /// - public partial class ConsumerInterceptor : MASES.JCOBridge.C2JBridge.JVMBridgeListener - { - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ConsumerInterceptor() { InitializeHandlers(); } - - const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.clients.consumer.ConsumerInterceptor"; - 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; - - - // TODO: complete the class - - } - #endregion - - #region ConsumerInterceptorDirect - /// - /// Direct override of or its generic type if there is one - /// - public partial class ConsumerInterceptorDirect : ConsumerInterceptor - { - /// - /// - /// - public override bool AutoInit => false; - - /// - protected override void InitializeHandlers() { } - - const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerInterceptor"; - 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; - } - #endregion - - #region ConsumerInterceptor - /// - /// - /// - /// - /// - public partial class ConsumerInterceptor : MASES.JCOBridge.C2JBridge.JVMBridgeListener - { - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ConsumerInterceptor() { InitializeHandlers(); } - - const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.clients.consumer.ConsumerInterceptor"; - 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; - - - // TODO: complete the class - - } - #endregion - - #region ConsumerInterceptorDirect - /// - /// Direct override of or its generic type if there is one - /// - public partial class ConsumerInterceptorDirect : ConsumerInterceptor - { - /// - /// - /// - public override bool AutoInit => false; - - /// - protected override void InitializeHandlers() { } - - const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerInterceptor"; - 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; - } - #endregion - - #region ConsumerPartitionAssignor - /// - /// - /// - public partial class ConsumerPartitionAssignor : MASES.JCOBridge.C2JBridge.JVMBridgeListener - { - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ConsumerPartitionAssignor() { InitializeHandlers(); } - - const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.clients.consumer.ConsumerPartitionAssignor"; - 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; - - - // TODO: complete the class - #region Assignment - /// - /// - /// - public partial class Assignment : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerPartitionAssignor$Assignment"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Assignment() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Assignment(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 GroupAssignment - /// - /// - /// - public partial class GroupAssignment : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerPartitionAssignor$GroupAssignment"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public GroupAssignment() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public GroupAssignment(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 GroupSubscription - /// - /// - /// - public partial class GroupSubscription : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerPartitionAssignor$GroupSubscription"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public GroupSubscription() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public GroupSubscription(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 RebalanceProtocol - /// - /// - /// - public partial class RebalanceProtocol : Java.Lang.Enum - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerPartitionAssignor$RebalanceProtocol"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public RebalanceProtocol() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public RebalanceProtocol(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 Subscription - /// - /// - /// - public partial class Subscription : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerPartitionAssignor$Subscription"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Subscription() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Subscription(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 ConsumerPartitionAssignorDirect - /// - /// Direct override of or its generic type if there is one - /// - public partial class ConsumerPartitionAssignorDirect : ConsumerPartitionAssignor - { - /// - /// - /// - public override bool AutoInit => false; - - /// - protected override void InitializeHandlers() { } - - const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerPartitionAssignor"; - 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; - } - #endregion - - #region ConsumerRebalanceListener - /// - /// - /// - public partial class ConsumerRebalanceListener : MASES.JCOBridge.C2JBridge.JVMBridgeListener - { - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ConsumerRebalanceListener() { InitializeHandlers(); } - - const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.clients.consumer.ConsumerRebalanceListener"; - 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; - - - // TODO: complete the class - - } - #endregion - - #region ConsumerRebalanceListenerDirect - /// - /// Direct override of or its generic type if there is one - /// - public partial class ConsumerRebalanceListenerDirect : ConsumerRebalanceListener - { - /// - /// - /// - public override bool AutoInit => false; - - /// - protected override void InitializeHandlers() { } - - const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerRebalanceListener"; - 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; - } - #endregion - - #region ConsumerRecord - /// - /// - /// - public partial class ConsumerRecord : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerRecord"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ConsumerRecord() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ConsumerRecord(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 ConsumerRecord - /// - /// - /// - /// - /// - public partial class ConsumerRecord : MASES.JCOBridge.C2JBridge.JVMBridgeBase> - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerRecord"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ConsumerRecord() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ConsumerRecord(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 ConsumerRecords - /// - /// - /// - public partial class ConsumerRecords : Java.Lang.Iterable - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerRecords"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ConsumerRecords() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ConsumerRecords(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 ConsumerRecords - /// - /// - /// - /// - /// - public partial class ConsumerRecords : Java.Lang.Iterable> - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerRecords"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ConsumerRecords() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ConsumerRecords(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 CooperativeStickyAssignor - /// - /// - /// - public partial class CooperativeStickyAssignor : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.CooperativeStickyAssignor"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public CooperativeStickyAssignor() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public CooperativeStickyAssignor(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 InvalidOffsetException - /// - /// - /// - public partial class InvalidOffsetException : Org.Apache.Kafka.Common.KafkaException - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.InvalidOffsetException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region KafkaConsumer - /// - /// - /// - public partial class KafkaConsumer : Org.Apache.Kafka.Clients.Consumer.Consumer - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.KafkaConsumer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public KafkaConsumer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public KafkaConsumer(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 KafkaConsumer - /// - /// - /// - /// - /// - public partial class KafkaConsumer : Org.Apache.Kafka.Clients.Consumer.Consumer - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.KafkaConsumer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public KafkaConsumer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public KafkaConsumer(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 LogTruncationException - /// - /// - /// - public partial class LogTruncationException : Org.Apache.Kafka.Clients.Consumer.OffsetOutOfRangeException - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.LogTruncationException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region MockConsumer - /// - /// - /// - public partial class MockConsumer : Org.Apache.Kafka.Clients.Consumer.Consumer - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.MockConsumer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public MockConsumer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public MockConsumer(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 MockConsumer - /// - /// - /// - /// - /// - public partial class MockConsumer : Org.Apache.Kafka.Clients.Consumer.Consumer - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.MockConsumer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public MockConsumer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public MockConsumer(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 NoOffsetForPartitionException - /// - /// - /// - public partial class NoOffsetForPartitionException : Org.Apache.Kafka.Clients.Consumer.InvalidOffsetException - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.NoOffsetForPartitionException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region OffsetAndMetadata - /// - /// - /// - public partial class OffsetAndMetadata : Java.Io.Serializable - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.OffsetAndMetadata"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public OffsetAndMetadata() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public OffsetAndMetadata(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 OffsetAndTimestamp - /// - /// - /// - public partial class OffsetAndTimestamp : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.OffsetAndTimestamp"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public OffsetAndTimestamp() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public OffsetAndTimestamp(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 OffsetCommitCallback - /// - /// - /// - public partial class OffsetCommitCallback : MASES.JCOBridge.C2JBridge.JVMBridgeListener - { - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public OffsetCommitCallback() { InitializeHandlers(); } - - const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.clients.consumer.OffsetCommitCallback"; - 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; - - - // TODO: complete the class - - } - #endregion - - #region OffsetCommitCallbackDirect - /// - /// Direct override of or its generic type if there is one - /// - public partial class OffsetCommitCallbackDirect : OffsetCommitCallback - { - /// - /// - /// - public override bool AutoInit => false; - - /// - protected override void InitializeHandlers() { } - - const string _bridgeClassName = "org.apache.kafka.clients.consumer.OffsetCommitCallback"; - 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; - } - #endregion - - #region OffsetOutOfRangeException - /// - /// - /// - public partial class OffsetOutOfRangeException : Org.Apache.Kafka.Clients.Consumer.InvalidOffsetException - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.OffsetOutOfRangeException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region OffsetResetStrategy - /// - /// - /// - public partial class OffsetResetStrategy : Java.Lang.Enum - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.OffsetResetStrategy"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public OffsetResetStrategy() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public OffsetResetStrategy(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 RangeAssignor - /// - /// - /// - public partial class RangeAssignor : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.RangeAssignor"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public RangeAssignor() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public RangeAssignor(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 RetriableCommitFailedException - /// - /// - /// - public partial class RetriableCommitFailedException : Org.Apache.Kafka.Common.Errors.RetriableException - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.RetriableCommitFailedException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region RoundRobinAssignor - /// - /// - /// - public partial class RoundRobinAssignor : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.RoundRobinAssignor"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public RoundRobinAssignor() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public RoundRobinAssignor(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 StickyAssignor - /// - /// - /// - public partial class StickyAssignor : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.clients.consumer.StickyAssignor"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public StickyAssignor() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public StickyAssignor(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/Consumer/CommitFailedException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/CommitFailedException.cs index 9b65407d7..1229ad687 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/CommitFailedException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/CommitFailedException.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,24 @@ namespace Org.Apache.Kafka.Clients.Consumer { - #region CommitFailedException + #region CommitFailedException declaration + /// + /// + /// + public partial class CommitFailedException : Org.Apache.Kafka.Common.KafkaException + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.CommitFailedException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region CommitFailedException implementation public partial class CommitFailedException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/Consumer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/Consumer.cs index 91cd039be..647c0cc70 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/Consumer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/Consumer.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,103 @@ namespace Org.Apache.Kafka.Clients.Consumer { - #region Consumer + #region Consumer declaration + /// + /// + /// + public partial class Consumer : Java.Io.Closeable + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.Consumer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("Consumer 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 Consumer() { } + /// + /// 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("Consumer 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 Consumer(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 Consumer declaration + /// + /// + /// + /// + /// + public partial class Consumer : Java.Io.Closeable + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.Consumer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("Consumer 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 Consumer() { } + /// + /// 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("Consumer 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 Consumer(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 Consumer implementation public partial class Consumer { #region Constructors @@ -455,7 +551,7 @@ public partial interface IConsumer : Java.Io.ICloseable } #endregion - #region Consumer + #region Consumer implementation public partial class Consumer : Org.Apache.Kafka.Clients.Consumer.IConsumer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/ConsumerConfig.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/ConsumerConfig.cs index e63c707ad..b2398923a 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/ConsumerConfig.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/ConsumerConfig.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.Consumer { - #region ConsumerConfig + #region ConsumerConfig declaration + /// + /// + /// + public partial class ConsumerConfig : Org.Apache.Kafka.Common.Config.AbstractConfig, MASES.JCOBridge.C2JBridge.IJVMBridgeMain + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerConfig"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ConsumerConfig() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ConsumerConfig(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 ConsumerConfig implementation public partial class ConsumerConfig { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/ConsumerGroupMetadata.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/ConsumerGroupMetadata.cs index bc2157135..b33762162 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/ConsumerGroupMetadata.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/ConsumerGroupMetadata.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.Consumer { - #region ConsumerGroupMetadata + #region ConsumerGroupMetadata declaration + /// + /// + /// + public partial class ConsumerGroupMetadata : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerGroupMetadata"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ConsumerGroupMetadata() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ConsumerGroupMetadata(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 ConsumerGroupMetadata implementation public partial class ConsumerGroupMetadata { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/ConsumerInterceptor.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/ConsumerInterceptor.cs index 8a1f247ba..e9bb7754f 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/ConsumerInterceptor.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/ConsumerInterceptor.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,143 @@ namespace Org.Apache.Kafka.Clients.Consumer { - #region ConsumerInterceptor + #region ConsumerInterceptor declaration + /// + /// + /// + public partial class ConsumerInterceptor : MASES.JCOBridge.C2JBridge.JVMBridgeListener + { + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ConsumerInterceptor() { InitializeHandlers(); } + + const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.clients.consumer.ConsumerInterceptor"; + private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = 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; + + + // TODO: complete the class + + } + #endregion + + #region ConsumerInterceptorDirect declaration + /// + /// Direct override of or its generic type if there is one + /// + public partial class ConsumerInterceptorDirect : ConsumerInterceptor + { + /// + /// + /// + public override bool AutoInit => false; + + /// + protected override void InitializeHandlers() { } + + const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerInterceptor"; + 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; + } + #endregion + + #region ConsumerInterceptor declaration + /// + /// + /// + /// + /// + public partial class ConsumerInterceptor : MASES.JCOBridge.C2JBridge.JVMBridgeListener + { + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ConsumerInterceptor() { InitializeHandlers(); } + + const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.clients.consumer.ConsumerInterceptor"; + private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = 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; + + + // TODO: complete the class + + } + #endregion + + #region ConsumerInterceptorDirect declaration + /// + /// Direct override of or its generic type if there is one + /// + public partial class ConsumerInterceptorDirect : ConsumerInterceptor + { + /// + /// + /// + public override bool AutoInit => false; + + /// + protected override void InitializeHandlers() { } + + const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerInterceptor"; + 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; + } + #endregion + + #region ConsumerInterceptor implementation public partial class ConsumerInterceptor { #region Constructors @@ -50,10 +186,10 @@ public partial class ConsumerInterceptor /// protected virtual void InitializeHandlers() { - AddEventHandler("onConsume", new global::System.EventHandler>>(OnConsumeEventHandler)); - AddEventHandler("close", new global::System.EventHandler>(CloseEventHandler)); - AddEventHandler("onCommit", new global::System.EventHandler>>(OnCommitEventHandler)); - AddEventHandler("configure", new global::System.EventHandler>>(ConfigureEventHandler)); + AddEventHandler("onConsume", new global::System.EventHandler>>(OnConsumeEventHandler)); + AddEventHandler("close", new global::System.EventHandler>>(CloseEventHandler)); + AddEventHandler("onCommit", new global::System.EventHandler>>(OnCommitEventHandler)); + AddEventHandler("configure", new global::System.EventHandler>>(ConfigureEventHandler)); } @@ -63,11 +199,13 @@ protected virtual void InitializeHandlers() /// If has a value it takes precedence over corresponding class method public global::System.Func OnOnConsume { get; set; } = null; - void OnConsumeEventHandler(object sender, CLRListenerEventArgs> data) + bool hasOverrideOnConsume = true; + void OnConsumeEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideOnConsume = true; var methodToExecute = (OnOnConsume != null) ? OnOnConsume : OnConsume; - var executionResult = methodToExecute.Invoke(data.EventData.TypedEventData); - data.SetReturnValue(executionResult); + var executionResult = methodToExecute.Invoke(data.EventData.GetAt(0)); + data.EventData.TypedEventData.SetReturnData(hasOverrideOnConsume, executionResult); } /// @@ -77,7 +215,7 @@ void OnConsumeEventHandler(object sender, CLRListenerEventArgs public virtual Org.Apache.Kafka.Clients.Consumer.ConsumerRecords OnConsume(Org.Apache.Kafka.Clients.Consumer.ConsumerRecords arg0) { - return default; + hasOverrideOnConsume = false; return default; } /// @@ -86,10 +224,13 @@ public virtual Org.Apache.Kafka.Clients.Consumer.ConsumerRecords OnConsume(Org.A /// If has a value it takes precedence over corresponding class method public global::System.Action OnClose { get; set; } = null; - void CloseEventHandler(object sender, CLRListenerEventArgs data) + bool hasOverrideClose = true; + void CloseEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideClose = true; var methodToExecute = (OnClose != null) ? OnClose : Close; methodToExecute.Invoke(); + data.EventData.TypedEventData.HasOverride = hasOverrideClose; } /// @@ -97,7 +238,7 @@ void CloseEventHandler(object sender, CLRListenerEventArgs data) /// public virtual void Close() { - + hasOverrideClose = false; } /// @@ -106,10 +247,13 @@ public virtual void Close() /// If has a value it takes precedence over corresponding class method public global::System.Action OnOnCommit { get; set; } = null; - void OnCommitEventHandler(object sender, CLRListenerEventArgs> data) + bool hasOverrideOnCommit = true; + void OnCommitEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideOnCommit = true; var methodToExecute = (OnOnCommit != null) ? OnOnCommit : OnCommit; - methodToExecute.Invoke(data.EventData.TypedEventData); + methodToExecute.Invoke(data.EventData.GetAt(0)); + data.EventData.TypedEventData.HasOverride = hasOverrideOnCommit; } /// @@ -118,7 +262,7 @@ void OnCommitEventHandler(object sender, CLRListenerEventArgs public virtual void OnCommit(Java.Util.Map arg0) { - + hasOverrideOnCommit = false; } /// @@ -127,10 +271,13 @@ public virtual void OnCommit(Java.Util.Map arg0) /// If has a value it takes precedence over corresponding class method public global::System.Action OnConfigure { get; set; } = null; - void ConfigureEventHandler(object sender, CLRListenerEventArgs> data) + bool hasOverrideConfigure = true; + void ConfigureEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideConfigure = true; var methodToExecute = (OnConfigure != null) ? OnConfigure : Configure; - methodToExecute.Invoke(data.EventData.TypedEventData); + methodToExecute.Invoke(data.EventData.GetAt(0)); + data.EventData.TypedEventData.HasOverride = hasOverrideConfigure; } /// @@ -139,7 +286,7 @@ void ConfigureEventHandler(object sender, CLRListenerEventArgs public virtual void Configure(Java.Util.Map arg0) { - + hasOverrideConfigure = false; } #endregion @@ -152,7 +299,7 @@ public virtual void Configure(Java.Util.Map arg0) } #endregion - #region ConsumerInterceptorDirect + #region ConsumerInterceptorDirect implementation public partial class ConsumerInterceptorDirect { #region Constructors @@ -233,7 +380,7 @@ public partial interface IConsumerInterceptor } #endregion - #region ConsumerInterceptor + #region ConsumerInterceptor implementation public partial class ConsumerInterceptor : Org.Apache.Kafka.Clients.Consumer.IConsumerInterceptor, Org.Apache.Kafka.Common.IConfigurable, Java.Lang.IAutoCloseable { #region Constructors @@ -258,10 +405,10 @@ public partial class ConsumerInterceptor : Org.Apache.Kafka.Clients.Consum /// protected virtual void InitializeHandlers() { - AddEventHandler("onConsume", new global::System.EventHandler>>>(OnConsumeEventHandler)); - AddEventHandler("close", new global::System.EventHandler>(CloseEventHandler)); - AddEventHandler("onCommit", new global::System.EventHandler>>>(OnCommitEventHandler)); - AddEventHandler("configure", new global::System.EventHandler>>>(ConfigureEventHandler)); + AddEventHandler("onConsume", new global::System.EventHandler>>(OnConsumeEventHandler)); + AddEventHandler("close", new global::System.EventHandler>>(CloseEventHandler)); + AddEventHandler("onCommit", new global::System.EventHandler>>(OnCommitEventHandler)); + AddEventHandler("configure", new global::System.EventHandler>>(ConfigureEventHandler)); } @@ -271,11 +418,13 @@ protected virtual void InitializeHandlers() /// If has a value it takes precedence over corresponding class method public global::System.Func, Org.Apache.Kafka.Clients.Consumer.ConsumerRecords> OnOnConsume { get; set; } = null; - void OnConsumeEventHandler(object sender, CLRListenerEventArgs>> data) + bool hasOverrideOnConsume = true; + void OnConsumeEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideOnConsume = true; var methodToExecute = (OnOnConsume != null) ? OnOnConsume : OnConsume; - var executionResult = methodToExecute.Invoke(data.EventData.TypedEventData); - data.SetReturnValue(executionResult); + var executionResult = methodToExecute.Invoke(data.EventData.GetAt>(0)); + data.EventData.TypedEventData.SetReturnData(hasOverrideOnConsume, executionResult); } /// @@ -285,7 +434,7 @@ void OnConsumeEventHandler(object sender, CLRListenerEventArgs public virtual Org.Apache.Kafka.Clients.Consumer.ConsumerRecords OnConsume(Org.Apache.Kafka.Clients.Consumer.ConsumerRecords arg0) { - return default; + hasOverrideOnConsume = false; return default; } /// @@ -294,10 +443,13 @@ public virtual Org.Apache.Kafka.Clients.Consumer.ConsumerRecords OnConsume /// If has a value it takes precedence over corresponding class method public global::System.Action OnClose { get; set; } = null; - void CloseEventHandler(object sender, CLRListenerEventArgs data) + bool hasOverrideClose = true; + void CloseEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideClose = true; var methodToExecute = (OnClose != null) ? OnClose : Close; methodToExecute.Invoke(); + data.EventData.TypedEventData.HasOverride = hasOverrideClose; } /// @@ -305,7 +457,7 @@ void CloseEventHandler(object sender, CLRListenerEventArgs data) /// public virtual void Close() { - + hasOverrideClose = false; } /// @@ -314,10 +466,13 @@ public virtual void Close() /// If has a value it takes precedence over corresponding class method public global::System.Action> OnOnCommit { get; set; } = null; - void OnCommitEventHandler(object sender, CLRListenerEventArgs>> data) + bool hasOverrideOnCommit = true; + void OnCommitEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideOnCommit = true; var methodToExecute = (OnOnCommit != null) ? OnOnCommit : OnCommit; - methodToExecute.Invoke(data.EventData.TypedEventData); + methodToExecute.Invoke(data.EventData.GetAt>(0)); + data.EventData.TypedEventData.HasOverride = hasOverrideOnCommit; } /// @@ -326,7 +481,7 @@ void OnCommitEventHandler(object sender, CLRListenerEventArgs public virtual void OnCommit(Java.Util.Map arg0) { - + hasOverrideOnCommit = false; } /// @@ -335,10 +490,13 @@ public virtual void OnCommit(Java.Util.MapIf has a value it takes precedence over corresponding class method public global::System.Action> OnConfigure { get; set; } = null; - void ConfigureEventHandler(object sender, CLRListenerEventArgs>> data) + bool hasOverrideConfigure = true; + void ConfigureEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideConfigure = true; var methodToExecute = (OnConfigure != null) ? OnConfigure : Configure; - methodToExecute.Invoke(data.EventData.TypedEventData); + methodToExecute.Invoke(data.EventData.GetAt>(0)); + data.EventData.TypedEventData.HasOverride = hasOverrideConfigure; } /// @@ -347,7 +505,7 @@ void ConfigureEventHandler(object sender, CLRListenerEventArgs public virtual void Configure(Java.Util.Map arg0) { - + hasOverrideConfigure = false; } #endregion @@ -360,7 +518,7 @@ public virtual void Configure(Java.Util.Map arg0) } #endregion - #region ConsumerInterceptorDirect + #region ConsumerInterceptorDirect implementation public partial class ConsumerInterceptorDirect : Org.Apache.Kafka.Clients.Consumer.IConsumerInterceptor, Org.Apache.Kafka.Common.IConfigurable, Java.Lang.IAutoCloseable { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/ConsumerPartitionAssignor.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/ConsumerPartitionAssignor.cs index 837d52e28..07b795b73 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/ConsumerPartitionAssignor.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/ConsumerPartitionAssignor.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,298 @@ namespace Org.Apache.Kafka.Clients.Consumer { + #region ConsumerPartitionAssignor declaration + /// + /// + /// + public partial class ConsumerPartitionAssignor : MASES.JCOBridge.C2JBridge.JVMBridgeListener + { + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ConsumerPartitionAssignor() { InitializeHandlers(); } + + const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.clients.consumer.ConsumerPartitionAssignor"; + private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = 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; + + + // TODO: complete the class + #region Assignment declaration + /// + /// + /// + public partial class Assignment : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerPartitionAssignor$Assignment"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Assignment() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Assignment(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 GroupAssignment declaration + /// + /// + /// + public partial class GroupAssignment : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerPartitionAssignor$GroupAssignment"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public GroupAssignment() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public GroupAssignment(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 GroupSubscription declaration + /// + /// + /// + public partial class GroupSubscription : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerPartitionAssignor$GroupSubscription"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public GroupSubscription() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public GroupSubscription(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 RebalanceProtocol declaration + /// + /// + /// + public partial class RebalanceProtocol : Java.Lang.Enum + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerPartitionAssignor$RebalanceProtocol"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public RebalanceProtocol() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public RebalanceProtocol(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 Subscription declaration + /// + /// + /// + public partial class Subscription : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerPartitionAssignor$Subscription"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Subscription() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Subscription(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 ConsumerPartitionAssignorDirect declaration + /// + /// Direct override of or its generic type if there is one + /// + public partial class ConsumerPartitionAssignorDirect : ConsumerPartitionAssignor + { + /// + /// + /// + public override bool AutoInit => false; + + /// + protected override void InitializeHandlers() { } + + const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerPartitionAssignor"; + 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; + } + #endregion + #region IConsumerPartitionAssignor /// /// .NET interface for org.mases.knet.generated.org.apache.kafka.clients.consumer.ConsumerPartitionAssignor implementing @@ -43,7 +335,7 @@ public partial interface IConsumerPartitionAssignor } #endregion - #region ConsumerPartitionAssignor + #region ConsumerPartitionAssignor implementation public partial class ConsumerPartitionAssignor : Org.Apache.Kafka.Clients.Consumer.IConsumerPartitionAssignor { #region Constructors @@ -79,12 +371,12 @@ public partial class ConsumerPartitionAssignor : Org.Apache.Kafka.Clients.Consum /// protected virtual void InitializeHandlers() { - AddEventHandler("name", new global::System.EventHandler>(NameEventHandler)); - AddEventHandler("assign", new global::System.EventHandler>>(AssignEventHandler)); - AddEventHandler("subscriptionUserData", new global::System.EventHandler>>>(SubscriptionUserDataEventHandler)); - AddEventHandler("supportedProtocols", new global::System.EventHandler>(SupportedProtocolsEventHandler)); - AddEventHandler("version", new global::System.EventHandler>(VersionEventHandler)); - AddEventHandler("onAssignment", new global::System.EventHandler>>(OnAssignmentEventHandler)); + AddEventHandler("name", new global::System.EventHandler>>(NameEventHandler)); + AddEventHandler("assign", new global::System.EventHandler>>(AssignEventHandler)); + AddEventHandler("subscriptionUserData", new global::System.EventHandler>>(SubscriptionUserDataEventHandler)); + AddEventHandler("supportedProtocols", new global::System.EventHandler>>(SupportedProtocolsEventHandler)); + AddEventHandler("version", new global::System.EventHandler>>(VersionEventHandler)); + AddEventHandler("onAssignment", new global::System.EventHandler>>(OnAssignmentEventHandler)); } @@ -94,11 +386,13 @@ protected virtual void InitializeHandlers() /// If has a value it takes precedence over corresponding class method public global::System.Func OnName { get; set; } = null; - void NameEventHandler(object sender, CLRListenerEventArgs data) + bool hasOverrideName = true; + void NameEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideName = true; var methodToExecute = (OnName != null) ? OnName : Name; var executionResult = methodToExecute.Invoke(); - data.SetReturnValue(executionResult); + data.EventData.TypedEventData.SetReturnData(hasOverrideName, executionResult); } /// @@ -107,7 +401,7 @@ void NameEventHandler(object sender, CLRListenerEventArgs data) /// public virtual Java.Lang.String Name() { - return default; + hasOverrideName = false; return default; } /// @@ -116,11 +410,13 @@ public virtual Java.Lang.String Name() /// If has a value it takes precedence over corresponding class method public global::System.Func OnAssign { get; set; } = null; - void AssignEventHandler(object sender, CLRListenerEventArgs> data) + bool hasOverrideAssign = true; + void AssignEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideAssign = true; var methodToExecute = (OnAssign != null) ? OnAssign : Assign; - var executionResult = methodToExecute.Invoke(data.EventData.TypedEventData, data.EventData.GetAt(0)); - data.SetReturnValue(executionResult); + var executionResult = methodToExecute.Invoke(data.EventData.GetAt(0), data.EventData.GetAt(1)); + data.EventData.TypedEventData.SetReturnData(hasOverrideAssign, executionResult); } /// @@ -131,7 +427,7 @@ void AssignEventHandler(object sender, CLRListenerEventArgs public virtual Org.Apache.Kafka.Clients.Consumer.ConsumerPartitionAssignor.GroupAssignment Assign(Org.Apache.Kafka.Common.Cluster arg0, Org.Apache.Kafka.Clients.Consumer.ConsumerPartitionAssignor.GroupSubscription arg1) { - return default; + hasOverrideAssign = false; return default; } /// /// @@ -150,11 +446,13 @@ public Java.Nio.ByteBuffer SubscriptionUserDataDefault(Java.Util.SetIf has a value it takes precedence over corresponding class method public global::System.Func, Java.Nio.ByteBuffer> OnSubscriptionUserData { get; set; } = null; - void SubscriptionUserDataEventHandler(object sender, CLRListenerEventArgs>> data) + bool hasOverrideSubscriptionUserData = true; + void SubscriptionUserDataEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideSubscriptionUserData = true; var methodToExecute = (OnSubscriptionUserData != null) ? OnSubscriptionUserData : SubscriptionUserData; - var executionResult = methodToExecute.Invoke(data.EventData.TypedEventData); - data.SetReturnValue(executionResult); + var executionResult = methodToExecute.Invoke(data.EventData.GetAt>(0)); + data.EventData.TypedEventData.SetReturnData(hasOverrideSubscriptionUserData, executionResult); } /// @@ -165,7 +463,7 @@ void SubscriptionUserDataEventHandler(object sender, CLRListenerEventArgsThe method invokes the default implementation in the JVM interface using ; override the method to implement a different behavior public virtual Java.Nio.ByteBuffer SubscriptionUserData(Java.Util.Set arg0) { - return SubscriptionUserDataDefault(arg0); + hasOverrideSubscriptionUserData = false; return default; } /// /// @@ -183,11 +481,13 @@ public virtual Java.Nio.ByteBuffer SubscriptionUserData(Java.Util.SetIf has a value it takes precedence over corresponding class method public global::System.Func> OnSupportedProtocols { get; set; } = null; - void SupportedProtocolsEventHandler(object sender, CLRListenerEventArgs data) + bool hasOverrideSupportedProtocols = true; + void SupportedProtocolsEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideSupportedProtocols = true; var methodToExecute = (OnSupportedProtocols != null) ? OnSupportedProtocols : SupportedProtocols; var executionResult = methodToExecute.Invoke(); - data.SetReturnValue(executionResult); + data.EventData.TypedEventData.SetReturnData(hasOverrideSupportedProtocols, executionResult); } /// @@ -197,7 +497,7 @@ void SupportedProtocolsEventHandler(object sender, CLRListenerEventArgsThe method invokes the default implementation in the JVM interface using ; override the method to implement a different behavior public virtual Java.Util.List SupportedProtocols() { - return SupportedProtocolsDefault(); + hasOverrideSupportedProtocols = false; return default; } /// /// @@ -215,11 +515,13 @@ public short VersionDefault() /// If has a value it takes precedence over corresponding class method public global::System.Func OnVersion { get; set; } = null; - void VersionEventHandler(object sender, CLRListenerEventArgs data) + bool hasOverrideVersion = true; + void VersionEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideVersion = true; var methodToExecute = (OnVersion != null) ? OnVersion : Version; var executionResult = methodToExecute.Invoke(); - data.SetReturnValue(executionResult); + data.EventData.TypedEventData.SetReturnData(hasOverrideVersion, executionResult); } /// @@ -229,7 +531,7 @@ void VersionEventHandler(object sender, CLRListenerEventArgs data) /// The method invokes the default implementation in the JVM interface using ; override the method to implement a different behavior public virtual short Version() { - return VersionDefault(); + hasOverrideVersion = false; return default; } /// /// @@ -248,10 +550,13 @@ public void OnAssignmentDefault(Org.Apache.Kafka.Clients.Consumer.ConsumerPartit /// If has a value it takes precedence over corresponding class method public global::System.Action OnOnAssignment { get; set; } = null; - void OnAssignmentEventHandler(object sender, CLRListenerEventArgs> data) + bool hasOverrideOnAssignment = true; + void OnAssignmentEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideOnAssignment = true; var methodToExecute = (OnOnAssignment != null) ? OnOnAssignment : OnAssignment; - methodToExecute.Invoke(data.EventData.TypedEventData, data.EventData.GetAt(0)); + methodToExecute.Invoke(data.EventData.GetAt(0), data.EventData.GetAt(1)); + data.EventData.TypedEventData.HasOverride = hasOverrideOnAssignment; } /// @@ -262,13 +567,13 @@ void OnAssignmentEventHandler(object sender, CLRListenerEventArgsThe method invokes the default implementation in the JVM interface using ; override the method to implement a different behavior public virtual void OnAssignment(Org.Apache.Kafka.Clients.Consumer.ConsumerPartitionAssignor.Assignment arg0, Org.Apache.Kafka.Clients.Consumer.ConsumerGroupMetadata arg1) { - OnAssignmentDefault(arg0, arg1); + hasOverrideOnAssignment = false; } #endregion #region Nested classes - #region Assignment + #region Assignment implementation public partial class Assignment { #region Constructors @@ -332,7 +637,7 @@ public Java.Nio.ByteBuffer UserData() } #endregion - #region GroupAssignment + #region GroupAssignment implementation public partial class GroupAssignment { #region Constructors @@ -379,7 +684,7 @@ public GroupAssignment(Java.Util.Map arg0) } #endregion - #region ConsumerPartitionAssignorDirect + #region ConsumerPartitionAssignorDirect implementation public partial class ConsumerPartitionAssignorDirect : Org.Apache.Kafka.Clients.Consumer.IConsumerPartitionAssignor { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/ConsumerRebalanceListener.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/ConsumerRebalanceListener.cs index c8627ff91..7e01614ec 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/ConsumerRebalanceListener.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/ConsumerRebalanceListener.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,73 @@ namespace Org.Apache.Kafka.Clients.Consumer { + #region ConsumerRebalanceListener declaration + /// + /// + /// + public partial class ConsumerRebalanceListener : MASES.JCOBridge.C2JBridge.JVMBridgeListener + { + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ConsumerRebalanceListener() { InitializeHandlers(); } + + const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.clients.consumer.ConsumerRebalanceListener"; + private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = 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; + + + // TODO: complete the class + + } + #endregion + + #region ConsumerRebalanceListenerDirect declaration + /// + /// Direct override of or its generic type if there is one + /// + public partial class ConsumerRebalanceListenerDirect : ConsumerRebalanceListener + { + /// + /// + /// + public override bool AutoInit => false; + + /// + protected override void InitializeHandlers() { } + + const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerRebalanceListener"; + 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; + } + #endregion + #region IConsumerRebalanceListener /// /// .NET interface for org.mases.knet.generated.org.apache.kafka.clients.consumer.ConsumerRebalanceListener implementing @@ -43,7 +110,7 @@ public partial interface IConsumerRebalanceListener } #endregion - #region ConsumerRebalanceListener + #region ConsumerRebalanceListener implementation public partial class ConsumerRebalanceListener : Org.Apache.Kafka.Clients.Consumer.IConsumerRebalanceListener { #region Constructors @@ -68,9 +135,9 @@ public partial class ConsumerRebalanceListener : Org.Apache.Kafka.Clients.Consum /// protected virtual void InitializeHandlers() { - AddEventHandler("onPartitionsAssigned", new global::System.EventHandler>>>(OnPartitionsAssignedEventHandler)); - AddEventHandler("onPartitionsRevoked", new global::System.EventHandler>>>(OnPartitionsRevokedEventHandler)); - AddEventHandler("onPartitionsLost", new global::System.EventHandler>>>(OnPartitionsLostEventHandler)); + AddEventHandler("onPartitionsAssigned", new global::System.EventHandler>>(OnPartitionsAssignedEventHandler)); + AddEventHandler("onPartitionsRevoked", new global::System.EventHandler>>(OnPartitionsRevokedEventHandler)); + AddEventHandler("onPartitionsLost", new global::System.EventHandler>>(OnPartitionsLostEventHandler)); } @@ -80,10 +147,13 @@ protected virtual void InitializeHandlers() /// If has a value it takes precedence over corresponding class method public global::System.Action> OnOnPartitionsAssigned { get; set; } = null; - void OnPartitionsAssignedEventHandler(object sender, CLRListenerEventArgs>> data) + bool hasOverrideOnPartitionsAssigned = true; + void OnPartitionsAssignedEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideOnPartitionsAssigned = true; var methodToExecute = (OnOnPartitionsAssigned != null) ? OnOnPartitionsAssigned : OnPartitionsAssigned; - methodToExecute.Invoke(data.EventData.TypedEventData); + methodToExecute.Invoke(data.EventData.GetAt>(0)); + data.EventData.TypedEventData.HasOverride = hasOverrideOnPartitionsAssigned; } /// @@ -92,7 +162,7 @@ void OnPartitionsAssignedEventHandler(object sender, CLRListenerEventArgs public virtual void OnPartitionsAssigned(Java.Util.Collection arg0) { - + hasOverrideOnPartitionsAssigned = false; } /// @@ -101,10 +171,13 @@ public virtual void OnPartitionsAssigned(Java.Util.CollectionIf has a value it takes precedence over corresponding class method public global::System.Action> OnOnPartitionsRevoked { get; set; } = null; - void OnPartitionsRevokedEventHandler(object sender, CLRListenerEventArgs>> data) + bool hasOverrideOnPartitionsRevoked = true; + void OnPartitionsRevokedEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideOnPartitionsRevoked = true; var methodToExecute = (OnOnPartitionsRevoked != null) ? OnOnPartitionsRevoked : OnPartitionsRevoked; - methodToExecute.Invoke(data.EventData.TypedEventData); + methodToExecute.Invoke(data.EventData.GetAt>(0)); + data.EventData.TypedEventData.HasOverride = hasOverrideOnPartitionsRevoked; } /// @@ -113,7 +186,7 @@ void OnPartitionsRevokedEventHandler(object sender, CLRListenerEventArgs public virtual void OnPartitionsRevoked(Java.Util.Collection arg0) { - + hasOverrideOnPartitionsRevoked = false; } /// /// @@ -131,10 +204,13 @@ public void OnPartitionsLostDefault(Java.Util.CollectionIf has a value it takes precedence over corresponding class method public global::System.Action> OnOnPartitionsLost { get; set; } = null; - void OnPartitionsLostEventHandler(object sender, CLRListenerEventArgs>> data) + bool hasOverrideOnPartitionsLost = true; + void OnPartitionsLostEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideOnPartitionsLost = true; var methodToExecute = (OnOnPartitionsLost != null) ? OnOnPartitionsLost : OnPartitionsLost; - methodToExecute.Invoke(data.EventData.TypedEventData); + methodToExecute.Invoke(data.EventData.GetAt>(0)); + data.EventData.TypedEventData.HasOverride = hasOverrideOnPartitionsLost; } /// @@ -144,7 +220,7 @@ void OnPartitionsLostEventHandler(object sender, CLRListenerEventArgsThe method invokes the default implementation in the JVM interface using ; override the method to implement a different behavior public virtual void OnPartitionsLost(Java.Util.Collection arg0) { - OnPartitionsLostDefault(arg0); + hasOverrideOnPartitionsLost = false; } #endregion @@ -157,7 +233,7 @@ public virtual void OnPartitionsLost(Java.Util.Collection + /// + /// + public partial class ConsumerRecord : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerRecord"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ConsumerRecord() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ConsumerRecord(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 ConsumerRecord declaration + /// + /// + /// + /// + /// + public partial class ConsumerRecord : MASES.JCOBridge.C2JBridge.JVMBridgeBase> + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerRecord"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ConsumerRecord() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ConsumerRecord(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 ConsumerRecord implementation public partial class ConsumerRecord { #region Constructors @@ -186,7 +278,7 @@ public object Value() } #endregion - #region ConsumerRecord + #region ConsumerRecord implementation public partial class ConsumerRecord { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/ConsumerRecords.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/ConsumerRecords.cs index c92036f23..4b4e360a0 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/ConsumerRecords.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/ConsumerRecords.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,99 @@ namespace Org.Apache.Kafka.Clients.Consumer { - #region ConsumerRecords + #region ConsumerRecords declaration + /// + /// + /// + public partial class ConsumerRecords : Java.Lang.Iterable + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerRecords"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ConsumerRecords() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ConsumerRecords(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 ConsumerRecords declaration + /// + /// + /// + /// + /// + public partial class ConsumerRecords : Java.Lang.Iterable> + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.ConsumerRecords"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ConsumerRecords() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ConsumerRecords(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 ConsumerRecords implementation public partial class ConsumerRecords { #region Constructors @@ -128,7 +220,7 @@ public Java.Util.Set Partitions() } #endregion - #region ConsumerRecords + #region ConsumerRecords implementation public partial class ConsumerRecords { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/CooperativeStickyAssignor.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/CooperativeStickyAssignor.cs index 9250b58a1..3f3a4e25d 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/CooperativeStickyAssignor.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/CooperativeStickyAssignor.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.Consumer { - #region CooperativeStickyAssignor + #region CooperativeStickyAssignor declaration + /// + /// + /// + public partial class CooperativeStickyAssignor : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.CooperativeStickyAssignor"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public CooperativeStickyAssignor() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public CooperativeStickyAssignor(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 CooperativeStickyAssignor implementation public partial class CooperativeStickyAssignor { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/InvalidOffsetException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/InvalidOffsetException.cs index af8498e3f..f27d3053f 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/InvalidOffsetException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/InvalidOffsetException.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,24 @@ namespace Org.Apache.Kafka.Clients.Consumer { - #region InvalidOffsetException + #region InvalidOffsetException declaration + /// + /// + /// + public partial class InvalidOffsetException : Org.Apache.Kafka.Common.KafkaException + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.InvalidOffsetException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region InvalidOffsetException implementation public partial class InvalidOffsetException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/KafkaConsumer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/KafkaConsumer.cs index 61e74943b..c89c629f4 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/KafkaConsumer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/KafkaConsumer.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,99 @@ namespace Org.Apache.Kafka.Clients.Consumer { - #region KafkaConsumer + #region KafkaConsumer declaration + /// + /// + /// + public partial class KafkaConsumer : Org.Apache.Kafka.Clients.Consumer.Consumer + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.KafkaConsumer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public KafkaConsumer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public KafkaConsumer(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 KafkaConsumer declaration + /// + /// + /// + /// + /// + public partial class KafkaConsumer : Org.Apache.Kafka.Clients.Consumer.Consumer + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.KafkaConsumer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public KafkaConsumer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public KafkaConsumer(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 KafkaConsumer implementation public partial class KafkaConsumer { #region Constructors @@ -473,7 +565,7 @@ public void Wakeup() } #endregion - #region KafkaConsumer + #region KafkaConsumer implementation public partial class KafkaConsumer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/LogTruncationException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/LogTruncationException.cs index 0322de08a..f675716de 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/LogTruncationException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/LogTruncationException.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,24 @@ namespace Org.Apache.Kafka.Clients.Consumer { - #region LogTruncationException + #region LogTruncationException declaration + /// + /// + /// + public partial class LogTruncationException : Org.Apache.Kafka.Clients.Consumer.OffsetOutOfRangeException + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.LogTruncationException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region LogTruncationException implementation public partial class LogTruncationException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/MockConsumer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/MockConsumer.cs index e843ca64b..58160b4a4 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/MockConsumer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/MockConsumer.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,99 @@ namespace Org.Apache.Kafka.Clients.Consumer { - #region MockConsumer + #region MockConsumer declaration + /// + /// + /// + public partial class MockConsumer : Org.Apache.Kafka.Clients.Consumer.Consumer + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.MockConsumer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public MockConsumer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public MockConsumer(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 MockConsumer declaration + /// + /// + /// + /// + /// + public partial class MockConsumer : Org.Apache.Kafka.Clients.Consumer.Consumer + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.MockConsumer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public MockConsumer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public MockConsumer(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 MockConsumer implementation public partial class MockConsumer { #region Constructors @@ -548,7 +640,7 @@ public void Seek(Org.Apache.Kafka.Common.TopicPartition arg0, Org.Apache.Kafka.C } #endregion - #region MockConsumer + #region MockConsumer implementation public partial class MockConsumer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/NoOffsetForPartitionException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/NoOffsetForPartitionException.cs index 3526d1602..ae0ba4023 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/NoOffsetForPartitionException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/NoOffsetForPartitionException.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,24 @@ namespace Org.Apache.Kafka.Clients.Consumer { - #region NoOffsetForPartitionException + #region NoOffsetForPartitionException declaration + /// + /// + /// + public partial class NoOffsetForPartitionException : Org.Apache.Kafka.Clients.Consumer.InvalidOffsetException + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.NoOffsetForPartitionException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region NoOffsetForPartitionException implementation public partial class NoOffsetForPartitionException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/OffsetAndMetadata.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/OffsetAndMetadata.cs index 9cc94901d..61421dae3 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/OffsetAndMetadata.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/OffsetAndMetadata.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.Consumer { - #region OffsetAndMetadata + #region OffsetAndMetadata declaration + /// + /// + /// + public partial class OffsetAndMetadata : Java.Io.Serializable + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.OffsetAndMetadata"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public OffsetAndMetadata() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public OffsetAndMetadata(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 OffsetAndMetadata implementation public partial class OffsetAndMetadata { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/OffsetAndTimestamp.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/OffsetAndTimestamp.cs index e537f1419..913fc6621 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/OffsetAndTimestamp.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/OffsetAndTimestamp.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.Consumer { - #region OffsetAndTimestamp + #region OffsetAndTimestamp declaration + /// + /// + /// + public partial class OffsetAndTimestamp : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.OffsetAndTimestamp"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public OffsetAndTimestamp() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public OffsetAndTimestamp(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 OffsetAndTimestamp implementation public partial class OffsetAndTimestamp { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/OffsetCommitCallback.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/OffsetCommitCallback.cs index ccdea881c..c7bc72145 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/OffsetCommitCallback.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/OffsetCommitCallback.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,73 @@ namespace Org.Apache.Kafka.Clients.Consumer { + #region OffsetCommitCallback declaration + /// + /// + /// + public partial class OffsetCommitCallback : MASES.JCOBridge.C2JBridge.JVMBridgeListener + { + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public OffsetCommitCallback() { InitializeHandlers(); } + + const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.clients.consumer.OffsetCommitCallback"; + private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = 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; + + + // TODO: complete the class + + } + #endregion + + #region OffsetCommitCallbackDirect declaration + /// + /// Direct override of or its generic type if there is one + /// + public partial class OffsetCommitCallbackDirect : OffsetCommitCallback + { + /// + /// + /// + public override bool AutoInit => false; + + /// + protected override void InitializeHandlers() { } + + const string _bridgeClassName = "org.apache.kafka.clients.consumer.OffsetCommitCallback"; + 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; + } + #endregion + #region IOffsetCommitCallback /// /// .NET interface for org.mases.knet.generated.org.apache.kafka.clients.consumer.OffsetCommitCallback implementing @@ -43,7 +110,7 @@ public partial interface IOffsetCommitCallback } #endregion - #region OffsetCommitCallback + #region OffsetCommitCallback implementation public partial class OffsetCommitCallback : Org.Apache.Kafka.Clients.Consumer.IOffsetCommitCallback { #region Constructors @@ -68,7 +135,7 @@ public partial class OffsetCommitCallback : Org.Apache.Kafka.Clients.Consumer.IO /// protected virtual void InitializeHandlers() { - AddEventHandler("onComplete", new global::System.EventHandler>>>(OnCompleteEventHandler)); + AddEventHandler("onComplete", new global::System.EventHandler>>(OnCompleteEventHandler)); } @@ -78,10 +145,13 @@ protected virtual void InitializeHandlers() /// If has a value it takes precedence over corresponding class method public global::System.Action, MASES.JCOBridge.C2JBridge.JVMBridgeException> OnOnComplete { get; set; } = null; - void OnCompleteEventHandler(object sender, CLRListenerEventArgs>> data) + bool hasOverrideOnComplete = true; + void OnCompleteEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideOnComplete = true; var methodToExecute = (OnOnComplete != null) ? OnOnComplete : OnComplete; - methodToExecute.Invoke(data.EventData.TypedEventData, JVMBridgeException.New(data.EventData.ExtraData.Get(0) as MASES.JCOBridge.C2JBridge.JVMInterop.IJavaObject)); + methodToExecute.Invoke(data.EventData.GetAt>(0), JVMBridgeException.New(data.EventData.ExtraData.Get(1) as MASES.JCOBridge.C2JBridge.JVMInterop.IJavaObject)); + data.EventData.TypedEventData.HasOverride = hasOverrideOnComplete; } /// @@ -91,7 +161,7 @@ void OnCompleteEventHandler(object sender, CLRListenerEventArgs public virtual void OnComplete(Java.Util.Map arg0, MASES.JCOBridge.C2JBridge.JVMBridgeException arg1) { - + hasOverrideOnComplete = false; } #endregion @@ -104,7 +174,7 @@ public virtual void OnComplete(Java.Util.Map + /// + /// + public partial class OffsetOutOfRangeException : Org.Apache.Kafka.Clients.Consumer.InvalidOffsetException + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.OffsetOutOfRangeException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region OffsetOutOfRangeException implementation public partial class OffsetOutOfRangeException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/OffsetResetStrategy.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/OffsetResetStrategy.cs index f42a49338..0f6f98457 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/OffsetResetStrategy.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/OffsetResetStrategy.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.Consumer { - #region OffsetResetStrategy + #region OffsetResetStrategy declaration + /// + /// + /// + public partial class OffsetResetStrategy : Java.Lang.Enum + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.OffsetResetStrategy"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public OffsetResetStrategy() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public OffsetResetStrategy(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 OffsetResetStrategy implementation public partial class OffsetResetStrategy { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/RangeAssignor.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/RangeAssignor.cs index 11c957490..3acd46306 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/RangeAssignor.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/RangeAssignor.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.Consumer { - #region RangeAssignor + #region RangeAssignor declaration + /// + /// + /// + public partial class RangeAssignor : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.RangeAssignor"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public RangeAssignor() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public RangeAssignor(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 RangeAssignor implementation public partial class RangeAssignor { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/RetriableCommitFailedException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/RetriableCommitFailedException.cs index 247c6201b..717ee9967 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/RetriableCommitFailedException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/RetriableCommitFailedException.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,24 @@ namespace Org.Apache.Kafka.Clients.Consumer { - #region RetriableCommitFailedException + #region RetriableCommitFailedException declaration + /// + /// + /// + public partial class RetriableCommitFailedException : Org.Apache.Kafka.Common.Errors.RetriableException + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.RetriableCommitFailedException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region RetriableCommitFailedException implementation public partial class RetriableCommitFailedException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/RoundRobinAssignor.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/RoundRobinAssignor.cs index c92f528d7..c5d0d7707 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/RoundRobinAssignor.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/RoundRobinAssignor.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.Consumer { - #region RoundRobinAssignor + #region RoundRobinAssignor declaration + /// + /// + /// + public partial class RoundRobinAssignor : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.RoundRobinAssignor"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public RoundRobinAssignor() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public RoundRobinAssignor(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 RoundRobinAssignor implementation public partial class RoundRobinAssignor { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/StickyAssignor.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/StickyAssignor.cs index 1be059e33..9b88a2732 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/StickyAssignor.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/StickyAssignor.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.Consumer { - #region StickyAssignor + #region StickyAssignor declaration + /// + /// + /// + public partial class StickyAssignor : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.clients.consumer.StickyAssignor"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public StickyAssignor() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public StickyAssignor(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 StickyAssignor implementation public partial class StickyAssignor { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/DefaultHostResolver.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/DefaultHostResolver.cs index 4144e8712..80514fb2b 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/DefaultHostResolver.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/DefaultHostResolver.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 { - #region DefaultHostResolver + #region DefaultHostResolver declaration + /// + /// + /// + public partial class DefaultHostResolver : Org.Apache.Kafka.Clients.HostResolver + { + const string _bridgeClassName = "org.apache.kafka.clients.DefaultHostResolver"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public DefaultHostResolver() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public DefaultHostResolver(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 DefaultHostResolver implementation public partial class DefaultHostResolver { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/GroupRebalanceConfig.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/GroupRebalanceConfig.cs index 037f00ae4..f969f7d85 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/GroupRebalanceConfig.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/GroupRebalanceConfig.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 { - #region GroupRebalanceConfig + #region GroupRebalanceConfig declaration + /// + /// + /// + public partial class GroupRebalanceConfig : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.clients.GroupRebalanceConfig"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public GroupRebalanceConfig() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public GroupRebalanceConfig(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 ProtocolType declaration + /// + /// + /// + public partial class ProtocolType : Java.Lang.Enum + { + const string _bridgeClassName = "org.apache.kafka.clients.GroupRebalanceConfig$ProtocolType"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ProtocolType() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ProtocolType(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 GroupRebalanceConfig implementation public partial class GroupRebalanceConfig { #region Constructors @@ -114,7 +204,7 @@ public GroupRebalanceConfig(Org.Apache.Kafka.Common.Config.AbstractConfig arg0, #endregion #region Nested classes - #region ProtocolType + #region ProtocolType implementation public partial class ProtocolType { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/HostResolver.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/HostResolver.cs index d031950a9..42299ea4f 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/HostResolver.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/HostResolver.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 { + #region HostResolver declaration + /// + /// + /// + public partial class HostResolver : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.clients.HostResolver"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("HostResolver 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 HostResolver() { } + /// + /// 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("HostResolver 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 HostResolver(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 IHostResolver /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +90,7 @@ public partial interface IHostResolver } #endregion - #region HostResolver + #region HostResolver implementation public partial class HostResolver : Org.Apache.Kafka.Clients.IHostResolver { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/ManualMetadataUpdater.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/ManualMetadataUpdater.cs index db5b907d1..2329a0b7c 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/ManualMetadataUpdater.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/ManualMetadataUpdater.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 { - #region ManualMetadataUpdater + #region ManualMetadataUpdater declaration + /// + /// + /// + public partial class ManualMetadataUpdater : Org.Apache.Kafka.Clients.MetadataUpdater + { + const string _bridgeClassName = "org.apache.kafka.clients.ManualMetadataUpdater"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ManualMetadataUpdater() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ManualMetadataUpdater(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 ManualMetadataUpdater implementation public partial class ManualMetadataUpdater { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Metadata.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Metadata.cs index e578220b3..3ce17b185 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Metadata.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Metadata.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,142 @@ namespace Org.Apache.Kafka.Clients { - #region Metadata + #region Metadata declaration + /// + /// + /// + public partial class Metadata : Java.Io.Closeable + { + const string _bridgeClassName = "org.apache.kafka.clients.Metadata"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Metadata() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Metadata(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 LeaderAndEpoch declaration + /// + /// + /// + public partial class LeaderAndEpoch : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.clients.Metadata$LeaderAndEpoch"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public LeaderAndEpoch() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public LeaderAndEpoch(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 MetadataRequestAndVersion declaration + /// + /// + /// + public partial class MetadataRequestAndVersion : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.clients.Metadata$MetadataRequestAndVersion"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public MetadataRequestAndVersion() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public MetadataRequestAndVersion(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 Metadata implementation public partial class Metadata { #region Constructors @@ -230,7 +365,7 @@ public void MaybeThrowExceptionForTopic(Java.Lang.String arg0) #endregion #region Nested classes - #region LeaderAndEpoch + #region LeaderAndEpoch implementation public partial class LeaderAndEpoch { #region Constructors @@ -290,7 +425,7 @@ public static Org.Apache.Kafka.Clients.Metadata.LeaderAndEpoch NoLeaderOrEpoch() } #endregion - #region MetadataRequestAndVersion + #region MetadataRequestAndVersion implementation public partial class MetadataRequestAndVersion { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/MetadataSnapshot.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/MetadataSnapshot.cs index 9540c4bb5..d0c3b37ea 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/MetadataSnapshot.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/MetadataSnapshot.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 { - #region MetadataSnapshot + #region MetadataSnapshot declaration + /// + /// + /// + public partial class MetadataSnapshot : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.clients.MetadataSnapshot"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public MetadataSnapshot() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public MetadataSnapshot(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 MetadataSnapshot implementation public partial class MetadataSnapshot { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/MetadataUpdater.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/MetadataUpdater.cs index c513d2b0f..13bd456ff 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/MetadataUpdater.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/MetadataUpdater.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 { + #region MetadataUpdater declaration + /// + /// + /// + public partial class MetadataUpdater : Java.Io.Closeable + { + const string _bridgeClassName = "org.apache.kafka.clients.MetadataUpdater"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("MetadataUpdater 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 MetadataUpdater() { } + /// + /// 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("MetadataUpdater 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 MetadataUpdater(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 IMetadataUpdater /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +90,7 @@ public partial interface IMetadataUpdater : Java.Io.ICloseable } #endregion - #region MetadataUpdater + #region MetadataUpdater implementation public partial class MetadataUpdater : Org.Apache.Kafka.Clients.IMetadataUpdater { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/NetworkClientUtils.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/NetworkClientUtils.cs index 96dcd73fb..9c14aca4d 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/NetworkClientUtils.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/NetworkClientUtils.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 { - #region NetworkClientUtils + #region NetworkClientUtils declaration + /// + /// + /// + public partial class NetworkClientUtils : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.clients.NetworkClientUtils"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public NetworkClientUtils() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public NetworkClientUtils(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 NetworkClientUtils implementation public partial class NetworkClientUtils { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/NodeApiVersions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/NodeApiVersions.cs index d2e66f12b..84f6953c6 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/NodeApiVersions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/NodeApiVersions.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 { - #region NodeApiVersions + #region NodeApiVersions declaration + /// + /// + /// + public partial class NodeApiVersions : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.clients.NodeApiVersions"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public NodeApiVersions() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public NodeApiVersions(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 NodeApiVersions implementation public partial class NodeApiVersions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/AllPackageClasses.cs deleted file mode 100644 index 3103ad468..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/AllPackageClasses.cs +++ /dev/null @@ -1,825 +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.Producer -{ - #region BufferExhaustedException - /// - /// - /// - public partial class BufferExhaustedException : Org.Apache.Kafka.Common.Errors.TimeoutException - { - const string _bridgeClassName = "org.apache.kafka.clients.producer.BufferExhaustedException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region Callback - /// - /// - /// - public partial class Callback : MASES.JCOBridge.C2JBridge.JVMBridgeListener - { - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Callback() { InitializeHandlers(); } - - const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.clients.producer.Callback"; - 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; - - - // TODO: complete the class - - } - #endregion - - #region CallbackDirect - /// - /// Direct override of or its generic type if there is one - /// - public partial class CallbackDirect : Callback - { - /// - /// - /// - public override bool AutoInit => false; - - /// - protected override void InitializeHandlers() { } - - const string _bridgeClassName = "org.apache.kafka.clients.producer.Callback"; - 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; - } - #endregion - - #region KafkaProducer - /// - /// - /// - public partial class KafkaProducer : Org.Apache.Kafka.Clients.Producer.Producer - { - const string _bridgeClassName = "org.apache.kafka.clients.producer.KafkaProducer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public KafkaProducer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public KafkaProducer(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 KafkaProducer - /// - /// - /// - /// - /// - public partial class KafkaProducer : Org.Apache.Kafka.Clients.Producer.Producer - { - const string _bridgeClassName = "org.apache.kafka.clients.producer.KafkaProducer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public KafkaProducer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public KafkaProducer(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 MockProducer - /// - /// - /// - public partial class MockProducer : Org.Apache.Kafka.Clients.Producer.Producer - { - const string _bridgeClassName = "org.apache.kafka.clients.producer.MockProducer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public MockProducer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public MockProducer(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 MockProducer - /// - /// - /// - /// - /// - public partial class MockProducer : Org.Apache.Kafka.Clients.Producer.Producer - { - const string _bridgeClassName = "org.apache.kafka.clients.producer.MockProducer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public MockProducer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public MockProducer(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 Partitioner - /// - /// - /// - public partial class Partitioner : MASES.JCOBridge.C2JBridge.JVMBridgeListener - { - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Partitioner() { InitializeHandlers(); } - - const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.clients.producer.Partitioner"; - 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; - - - // TODO: complete the class - - } - #endregion - - #region PartitionerDirect - /// - /// Direct override of or its generic type if there is one - /// - public partial class PartitionerDirect : Partitioner - { - /// - /// - /// - public override bool AutoInit => false; - - /// - protected override void InitializeHandlers() { } - - const string _bridgeClassName = "org.apache.kafka.clients.producer.Partitioner"; - 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; - } - #endregion - - #region Producer - /// - /// - /// - public partial class Producer : Java.Io.Closeable - { - const string _bridgeClassName = "org.apache.kafka.clients.producer.Producer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("Producer 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 Producer() { } - /// - /// 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("Producer 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 Producer(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 Producer - /// - /// - /// - /// - /// - public partial class Producer : Java.Io.Closeable - { - const string _bridgeClassName = "org.apache.kafka.clients.producer.Producer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("Producer 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 Producer() { } - /// - /// 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("Producer 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 Producer(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 ProducerConfig - /// - /// - /// - public partial class ProducerConfig : Org.Apache.Kafka.Common.Config.AbstractConfig, MASES.JCOBridge.C2JBridge.IJVMBridgeMain - { - const string _bridgeClassName = "org.apache.kafka.clients.producer.ProducerConfig"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ProducerConfig() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ProducerConfig(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 ProducerInterceptor - /// - /// - /// - public partial class ProducerInterceptor : MASES.JCOBridge.C2JBridge.JVMBridgeListener - { - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ProducerInterceptor() { InitializeHandlers(); } - - const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.clients.producer.ProducerInterceptor"; - 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; - - - // TODO: complete the class - - } - #endregion - - #region ProducerInterceptorDirect - /// - /// Direct override of or its generic type if there is one - /// - public partial class ProducerInterceptorDirect : ProducerInterceptor - { - /// - /// - /// - public override bool AutoInit => false; - - /// - protected override void InitializeHandlers() { } - - const string _bridgeClassName = "org.apache.kafka.clients.producer.ProducerInterceptor"; - 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; - } - #endregion - - #region ProducerInterceptor - /// - /// - /// - /// - /// - public partial class ProducerInterceptor : MASES.JCOBridge.C2JBridge.JVMBridgeListener - { - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ProducerInterceptor() { InitializeHandlers(); } - - const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.clients.producer.ProducerInterceptor"; - 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; - - - // TODO: complete the class - - } - #endregion - - #region ProducerInterceptorDirect - /// - /// Direct override of or its generic type if there is one - /// - public partial class ProducerInterceptorDirect : ProducerInterceptor - { - /// - /// - /// - public override bool AutoInit => false; - - /// - protected override void InitializeHandlers() { } - - const string _bridgeClassName = "org.apache.kafka.clients.producer.ProducerInterceptor"; - 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; - } - #endregion - - #region ProducerRecord - /// - /// - /// - public partial class ProducerRecord : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.clients.producer.ProducerRecord"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ProducerRecord() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ProducerRecord(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 ProducerRecord - /// - /// - /// - /// - /// - public partial class ProducerRecord : MASES.JCOBridge.C2JBridge.JVMBridgeBase> - { - const string _bridgeClassName = "org.apache.kafka.clients.producer.ProducerRecord"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ProducerRecord() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ProducerRecord(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 RecordMetadata - /// - /// - /// - public partial class RecordMetadata : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.clients.producer.RecordMetadata"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public RecordMetadata() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public RecordMetadata(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 RoundRobinPartitioner - /// - /// - /// - public partial class RoundRobinPartitioner : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.clients.producer.RoundRobinPartitioner"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public RoundRobinPartitioner() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public RoundRobinPartitioner(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/Producer/BufferExhaustedException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/BufferExhaustedException.cs index 2d22782f3..ee13554b5 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/BufferExhaustedException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/BufferExhaustedException.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,24 @@ namespace Org.Apache.Kafka.Clients.Producer { - #region BufferExhaustedException + #region BufferExhaustedException declaration + /// + /// + /// + public partial class BufferExhaustedException : Org.Apache.Kafka.Common.Errors.TimeoutException + { + const string _bridgeClassName = "org.apache.kafka.clients.producer.BufferExhaustedException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region BufferExhaustedException implementation public partial class BufferExhaustedException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/Callback.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/Callback.cs index 0089fc1cf..542ad7ebf 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/Callback.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/Callback.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,73 @@ namespace Org.Apache.Kafka.Clients.Producer { + #region Callback declaration + /// + /// + /// + public partial class Callback : MASES.JCOBridge.C2JBridge.JVMBridgeListener + { + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Callback() { InitializeHandlers(); } + + const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.clients.producer.Callback"; + private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = 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; + + + // TODO: complete the class + + } + #endregion + + #region CallbackDirect declaration + /// + /// Direct override of or its generic type if there is one + /// + public partial class CallbackDirect : Callback + { + /// + /// + /// + public override bool AutoInit => false; + + /// + protected override void InitializeHandlers() { } + + const string _bridgeClassName = "org.apache.kafka.clients.producer.Callback"; + 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; + } + #endregion + #region ICallback /// /// .NET interface for org.mases.knet.generated.org.apache.kafka.clients.producer.Callback implementing @@ -43,7 +110,7 @@ public partial interface ICallback } #endregion - #region Callback + #region Callback implementation public partial class Callback : Org.Apache.Kafka.Clients.Producer.ICallback { #region Constructors @@ -68,7 +135,7 @@ public partial class Callback : Org.Apache.Kafka.Clients.Producer.ICallback /// protected virtual void InitializeHandlers() { - AddEventHandler("onCompletion", new global::System.EventHandler>>(OnCompletionEventHandler)); + AddEventHandler("onCompletion", new global::System.EventHandler>>(OnCompletionEventHandler)); } @@ -78,10 +145,13 @@ protected virtual void InitializeHandlers() /// If has a value it takes precedence over corresponding class method public global::System.Action OnOnCompletion { get; set; } = null; - void OnCompletionEventHandler(object sender, CLRListenerEventArgs> data) + bool hasOverrideOnCompletion = true; + void OnCompletionEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideOnCompletion = true; var methodToExecute = (OnOnCompletion != null) ? OnOnCompletion : OnCompletion; - methodToExecute.Invoke(data.EventData.TypedEventData, JVMBridgeException.New(data.EventData.ExtraData.Get(0) as MASES.JCOBridge.C2JBridge.JVMInterop.IJavaObject)); + methodToExecute.Invoke(data.EventData.GetAt(0), JVMBridgeException.New(data.EventData.ExtraData.Get(1) as MASES.JCOBridge.C2JBridge.JVMInterop.IJavaObject)); + data.EventData.TypedEventData.HasOverride = hasOverrideOnCompletion; } /// @@ -91,7 +161,7 @@ void OnCompletionEventHandler(object sender, CLRListenerEventArgs public virtual void OnCompletion(Org.Apache.Kafka.Clients.Producer.RecordMetadata arg0, MASES.JCOBridge.C2JBridge.JVMBridgeException arg1) { - + hasOverrideOnCompletion = false; } #endregion @@ -104,7 +174,7 @@ public virtual void OnCompletion(Org.Apache.Kafka.Clients.Producer.RecordMetadat } #endregion - #region CallbackDirect + #region CallbackDirect implementation public partial class CallbackDirect : Org.Apache.Kafka.Clients.Producer.ICallback { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/KafkaProducer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/KafkaProducer.cs index 8da99b478..6ad79cee5 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/KafkaProducer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/KafkaProducer.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,99 @@ namespace Org.Apache.Kafka.Clients.Producer { - #region KafkaProducer + #region KafkaProducer declaration + /// + /// + /// + public partial class KafkaProducer : Org.Apache.Kafka.Clients.Producer.Producer + { + const string _bridgeClassName = "org.apache.kafka.clients.producer.KafkaProducer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public KafkaProducer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public KafkaProducer(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 KafkaProducer declaration + /// + /// + /// + /// + /// + public partial class KafkaProducer : Org.Apache.Kafka.Clients.Producer.Producer + { + const string _bridgeClassName = "org.apache.kafka.clients.producer.KafkaProducer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public KafkaProducer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public KafkaProducer(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 KafkaProducer implementation public partial class KafkaProducer { #region Constructors @@ -203,7 +295,7 @@ public void SendOffsetsToTransaction(Java.Util.Map arg0, Org.Apache.Kafka.Client } #endregion - #region KafkaProducer + #region KafkaProducer implementation public partial class KafkaProducer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/MockProducer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/MockProducer.cs index af6a79f47..77e829d20 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/MockProducer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/MockProducer.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,99 @@ namespace Org.Apache.Kafka.Clients.Producer { - #region MockProducer + #region MockProducer declaration + /// + /// + /// + public partial class MockProducer : Org.Apache.Kafka.Clients.Producer.Producer + { + const string _bridgeClassName = "org.apache.kafka.clients.producer.MockProducer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public MockProducer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public MockProducer(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 MockProducer declaration + /// + /// + /// + /// + /// + public partial class MockProducer : Org.Apache.Kafka.Clients.Producer.Producer + { + const string _bridgeClassName = "org.apache.kafka.clients.producer.MockProducer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public MockProducer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public MockProducer(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 MockProducer implementation public partial class MockProducer { #region Constructors @@ -371,7 +463,7 @@ public void SetMockMetrics(Org.Apache.Kafka.Common.MetricName arg0, Org.Apache.K } #endregion - #region MockProducer + #region MockProducer implementation public partial class MockProducer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/Partitioner.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/Partitioner.cs index 3ed78f79e..373ede412 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/Partitioner.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/Partitioner.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,73 @@ namespace Org.Apache.Kafka.Clients.Producer { + #region Partitioner declaration + /// + /// + /// + public partial class Partitioner : MASES.JCOBridge.C2JBridge.JVMBridgeListener + { + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Partitioner() { InitializeHandlers(); } + + const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.clients.producer.Partitioner"; + private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = 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; + + + // TODO: complete the class + + } + #endregion + + #region PartitionerDirect declaration + /// + /// Direct override of or its generic type if there is one + /// + public partial class PartitionerDirect : Partitioner + { + /// + /// + /// + public override bool AutoInit => false; + + /// + protected override void InitializeHandlers() { } + + const string _bridgeClassName = "org.apache.kafka.clients.producer.Partitioner"; + 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; + } + #endregion + #region IPartitioner /// /// .NET interface for org.mases.knet.generated.org.apache.kafka.clients.producer.Partitioner implementing @@ -43,7 +110,7 @@ public partial interface IPartitioner } #endregion - #region Partitioner + #region Partitioner implementation public partial class Partitioner : Org.Apache.Kafka.Clients.Producer.IPartitioner, Org.Apache.Kafka.Common.IConfigurable, Java.Io.ICloseable { #region Constructors @@ -68,9 +135,9 @@ public partial class Partitioner : Org.Apache.Kafka.Clients.Producer.IPartitione /// protected virtual void InitializeHandlers() { - AddEventHandler("partition", new global::System.EventHandler>>(PartitionEventHandler)); - AddEventHandler("close", new global::System.EventHandler>(CloseEventHandler)); - AddEventHandler("configure", new global::System.EventHandler>>>(ConfigureEventHandler)); + AddEventHandler("partition", new global::System.EventHandler>>(PartitionEventHandler)); + AddEventHandler("close", new global::System.EventHandler>>(CloseEventHandler)); + AddEventHandler("configure", new global::System.EventHandler>>(ConfigureEventHandler)); } @@ -80,11 +147,13 @@ protected virtual void InitializeHandlers() /// If has a value it takes precedence over corresponding class method public global::System.Func OnPartition { get; set; } = null; - void PartitionEventHandler(object sender, CLRListenerEventArgs> data) + bool hasOverridePartition = true; + void PartitionEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverridePartition = true; var methodToExecute = (OnPartition != null) ? OnPartition : Partition; - var executionResult = methodToExecute.Invoke(data.EventData.TypedEventData, data.EventData.GetAt(0), data.EventData.GetAt(1), data.EventData.GetAt(2), data.EventData.GetAt(3), data.EventData.GetAt(4)); - data.SetReturnValue(executionResult); + var executionResult = methodToExecute.Invoke(data.EventData.GetAt(0), data.EventData.GetAt(1), data.EventData.GetAt(2), data.EventData.GetAt(3), data.EventData.GetAt(4), data.EventData.GetAt(5)); + data.EventData.TypedEventData.SetReturnData(hasOverridePartition, executionResult); } /// @@ -99,7 +168,7 @@ void PartitionEventHandler(object sender, CLRListenerEventArgs public virtual int Partition(Java.Lang.String arg0, object arg1, byte[] arg2, object arg3, byte[] arg4, Org.Apache.Kafka.Common.Cluster arg5) { - return default; + hasOverridePartition = false; return default; } /// @@ -108,10 +177,13 @@ public virtual int Partition(Java.Lang.String arg0, object arg1, byte[] arg2, ob /// If has a value it takes precedence over corresponding class method public global::System.Action OnClose { get; set; } = null; - void CloseEventHandler(object sender, CLRListenerEventArgs data) + bool hasOverrideClose = true; + void CloseEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideClose = true; var methodToExecute = (OnClose != null) ? OnClose : Close; methodToExecute.Invoke(); + data.EventData.TypedEventData.HasOverride = hasOverrideClose; } /// @@ -119,7 +191,7 @@ void CloseEventHandler(object sender, CLRListenerEventArgs data) /// public virtual void Close() { - + hasOverrideClose = false; } /// @@ -128,10 +200,13 @@ public virtual void Close() /// If has a value it takes precedence over corresponding class method public global::System.Action> OnConfigure { get; set; } = null; - void ConfigureEventHandler(object sender, CLRListenerEventArgs>> data) + bool hasOverrideConfigure = true; + void ConfigureEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideConfigure = true; var methodToExecute = (OnConfigure != null) ? OnConfigure : Configure; - methodToExecute.Invoke(data.EventData.TypedEventData); + methodToExecute.Invoke(data.EventData.GetAt>(0)); + data.EventData.TypedEventData.HasOverride = hasOverrideConfigure; } /// @@ -140,7 +215,7 @@ void ConfigureEventHandler(object sender, CLRListenerEventArgs public virtual void Configure(Java.Util.Map arg0) { - + hasOverrideConfigure = false; } #endregion @@ -153,7 +228,7 @@ public virtual void Configure(Java.Util.Map arg0) } #endregion - #region PartitionerDirect + #region PartitionerDirect implementation public partial class PartitionerDirect : Org.Apache.Kafka.Clients.Producer.IPartitioner, Org.Apache.Kafka.Common.IConfigurable, Java.Io.ICloseable { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/Producer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/Producer.cs index b1f18f012..09f9fb484 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/Producer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/Producer.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,103 @@ namespace Org.Apache.Kafka.Clients.Producer { - #region Producer + #region Producer declaration + /// + /// + /// + public partial class Producer : Java.Io.Closeable + { + const string _bridgeClassName = "org.apache.kafka.clients.producer.Producer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("Producer 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 Producer() { } + /// + /// 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("Producer 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 Producer(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 Producer declaration + /// + /// + /// + /// + /// + public partial class Producer : Java.Io.Closeable + { + const string _bridgeClassName = "org.apache.kafka.clients.producer.Producer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("Producer 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 Producer() { } + /// + /// 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("Producer 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 Producer(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 Producer implementation public partial class Producer { #region Constructors @@ -173,7 +269,7 @@ public partial interface IProducer : Java.Io.ICloseable } #endregion - #region Producer + #region Producer implementation public partial class Producer : Org.Apache.Kafka.Clients.Producer.IProducer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/ProducerConfig.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/ProducerConfig.cs index 8e194a06d..a1f876d8b 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/ProducerConfig.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/ProducerConfig.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.Producer { - #region ProducerConfig + #region ProducerConfig declaration + /// + /// + /// + public partial class ProducerConfig : Org.Apache.Kafka.Common.Config.AbstractConfig, MASES.JCOBridge.C2JBridge.IJVMBridgeMain + { + const string _bridgeClassName = "org.apache.kafka.clients.producer.ProducerConfig"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ProducerConfig() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ProducerConfig(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 ProducerConfig implementation public partial class ProducerConfig { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/ProducerInterceptor.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/ProducerInterceptor.cs index e55d9566d..e40fc97b4 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/ProducerInterceptor.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/ProducerInterceptor.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,143 @@ namespace Org.Apache.Kafka.Clients.Producer { - #region ProducerInterceptor + #region ProducerInterceptor declaration + /// + /// + /// + public partial class ProducerInterceptor : MASES.JCOBridge.C2JBridge.JVMBridgeListener + { + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ProducerInterceptor() { InitializeHandlers(); } + + const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.clients.producer.ProducerInterceptor"; + private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = 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; + + + // TODO: complete the class + + } + #endregion + + #region ProducerInterceptorDirect declaration + /// + /// Direct override of or its generic type if there is one + /// + public partial class ProducerInterceptorDirect : ProducerInterceptor + { + /// + /// + /// + public override bool AutoInit => false; + + /// + protected override void InitializeHandlers() { } + + const string _bridgeClassName = "org.apache.kafka.clients.producer.ProducerInterceptor"; + 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; + } + #endregion + + #region ProducerInterceptor declaration + /// + /// + /// + /// + /// + public partial class ProducerInterceptor : MASES.JCOBridge.C2JBridge.JVMBridgeListener + { + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ProducerInterceptor() { InitializeHandlers(); } + + const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.clients.producer.ProducerInterceptor"; + private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = 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; + + + // TODO: complete the class + + } + #endregion + + #region ProducerInterceptorDirect declaration + /// + /// Direct override of or its generic type if there is one + /// + public partial class ProducerInterceptorDirect : ProducerInterceptor + { + /// + /// + /// + public override bool AutoInit => false; + + /// + protected override void InitializeHandlers() { } + + const string _bridgeClassName = "org.apache.kafka.clients.producer.ProducerInterceptor"; + 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; + } + #endregion + + #region ProducerInterceptor implementation public partial class ProducerInterceptor { #region Constructors @@ -50,10 +186,10 @@ public partial class ProducerInterceptor /// protected virtual void InitializeHandlers() { - AddEventHandler("onSend", new global::System.EventHandler>>(OnSendEventHandler)); - AddEventHandler("close", new global::System.EventHandler>(CloseEventHandler)); - AddEventHandler("onAcknowledgement", new global::System.EventHandler>>(OnAcknowledgementEventHandler)); - AddEventHandler("configure", new global::System.EventHandler>>(ConfigureEventHandler)); + AddEventHandler("onSend", new global::System.EventHandler>>(OnSendEventHandler)); + AddEventHandler("close", new global::System.EventHandler>>(CloseEventHandler)); + AddEventHandler("onAcknowledgement", new global::System.EventHandler>>(OnAcknowledgementEventHandler)); + AddEventHandler("configure", new global::System.EventHandler>>(ConfigureEventHandler)); } @@ -63,11 +199,13 @@ protected virtual void InitializeHandlers() /// If has a value it takes precedence over corresponding class method public global::System.Func OnOnSend { get; set; } = null; - void OnSendEventHandler(object sender, CLRListenerEventArgs> data) + bool hasOverrideOnSend = true; + void OnSendEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideOnSend = true; var methodToExecute = (OnOnSend != null) ? OnOnSend : OnSend; - var executionResult = methodToExecute.Invoke(data.EventData.TypedEventData); - data.SetReturnValue(executionResult); + var executionResult = methodToExecute.Invoke(data.EventData.GetAt(0)); + data.EventData.TypedEventData.SetReturnData(hasOverrideOnSend, executionResult); } /// @@ -77,7 +215,7 @@ void OnSendEventHandler(object sender, CLRListenerEventArgs public virtual Org.Apache.Kafka.Clients.Producer.ProducerRecord OnSend(Org.Apache.Kafka.Clients.Producer.ProducerRecord arg0) { - return default; + hasOverrideOnSend = false; return default; } /// @@ -86,10 +224,13 @@ public virtual Org.Apache.Kafka.Clients.Producer.ProducerRecord OnSend(Org.Apach /// If has a value it takes precedence over corresponding class method public global::System.Action OnClose { get; set; } = null; - void CloseEventHandler(object sender, CLRListenerEventArgs data) + bool hasOverrideClose = true; + void CloseEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideClose = true; var methodToExecute = (OnClose != null) ? OnClose : Close; methodToExecute.Invoke(); + data.EventData.TypedEventData.HasOverride = hasOverrideClose; } /// @@ -97,7 +238,7 @@ void CloseEventHandler(object sender, CLRListenerEventArgs data) /// public virtual void Close() { - + hasOverrideClose = false; } /// @@ -106,10 +247,13 @@ public virtual void Close() /// If has a value it takes precedence over corresponding class method public global::System.Action OnOnAcknowledgement { get; set; } = null; - void OnAcknowledgementEventHandler(object sender, CLRListenerEventArgs> data) + bool hasOverrideOnAcknowledgement = true; + void OnAcknowledgementEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideOnAcknowledgement = true; var methodToExecute = (OnOnAcknowledgement != null) ? OnOnAcknowledgement : OnAcknowledgement; - methodToExecute.Invoke(data.EventData.TypedEventData, JVMBridgeException.New(data.EventData.ExtraData.Get(0) as MASES.JCOBridge.C2JBridge.JVMInterop.IJavaObject)); + methodToExecute.Invoke(data.EventData.GetAt(0), JVMBridgeException.New(data.EventData.ExtraData.Get(1) as MASES.JCOBridge.C2JBridge.JVMInterop.IJavaObject)); + data.EventData.TypedEventData.HasOverride = hasOverrideOnAcknowledgement; } /// @@ -119,7 +263,7 @@ void OnAcknowledgementEventHandler(object sender, CLRListenerEventArgs public virtual void OnAcknowledgement(Org.Apache.Kafka.Clients.Producer.RecordMetadata arg0, MASES.JCOBridge.C2JBridge.JVMBridgeException arg1) { - + hasOverrideOnAcknowledgement = false; } /// @@ -128,10 +272,13 @@ public virtual void OnAcknowledgement(Org.Apache.Kafka.Clients.Producer.RecordMe /// If has a value it takes precedence over corresponding class method public global::System.Action OnConfigure { get; set; } = null; - void ConfigureEventHandler(object sender, CLRListenerEventArgs> data) + bool hasOverrideConfigure = true; + void ConfigureEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideConfigure = true; var methodToExecute = (OnConfigure != null) ? OnConfigure : Configure; - methodToExecute.Invoke(data.EventData.TypedEventData); + methodToExecute.Invoke(data.EventData.GetAt(0)); + data.EventData.TypedEventData.HasOverride = hasOverrideConfigure; } /// @@ -140,7 +287,7 @@ void ConfigureEventHandler(object sender, CLRListenerEventArgs public virtual void Configure(Java.Util.Map arg0) { - + hasOverrideConfigure = false; } #endregion @@ -153,7 +300,7 @@ public virtual void Configure(Java.Util.Map arg0) } #endregion - #region ProducerInterceptorDirect + #region ProducerInterceptorDirect implementation public partial class ProducerInterceptorDirect { #region Constructors @@ -235,7 +382,7 @@ public partial interface IProducerInterceptor } #endregion - #region ProducerInterceptor + #region ProducerInterceptor implementation public partial class ProducerInterceptor : Org.Apache.Kafka.Clients.Producer.IProducerInterceptor, Org.Apache.Kafka.Common.IConfigurable, Java.Lang.IAutoCloseable { #region Constructors @@ -260,10 +407,10 @@ public partial class ProducerInterceptor : Org.Apache.Kafka.Clients.Produc /// protected virtual void InitializeHandlers() { - AddEventHandler("onSend", new global::System.EventHandler>>>(OnSendEventHandler)); - AddEventHandler("close", new global::System.EventHandler>(CloseEventHandler)); - AddEventHandler("onAcknowledgement", new global::System.EventHandler>>(OnAcknowledgementEventHandler)); - AddEventHandler("configure", new global::System.EventHandler>>>(ConfigureEventHandler)); + AddEventHandler("onSend", new global::System.EventHandler>>(OnSendEventHandler)); + AddEventHandler("close", new global::System.EventHandler>>(CloseEventHandler)); + AddEventHandler("onAcknowledgement", new global::System.EventHandler>>(OnAcknowledgementEventHandler)); + AddEventHandler("configure", new global::System.EventHandler>>(ConfigureEventHandler)); } @@ -273,11 +420,13 @@ protected virtual void InitializeHandlers() /// If has a value it takes precedence over corresponding class method public global::System.Func, Org.Apache.Kafka.Clients.Producer.ProducerRecord> OnOnSend { get; set; } = null; - void OnSendEventHandler(object sender, CLRListenerEventArgs>> data) + bool hasOverrideOnSend = true; + void OnSendEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideOnSend = true; var methodToExecute = (OnOnSend != null) ? OnOnSend : OnSend; - var executionResult = methodToExecute.Invoke(data.EventData.TypedEventData); - data.SetReturnValue(executionResult); + var executionResult = methodToExecute.Invoke(data.EventData.GetAt>(0)); + data.EventData.TypedEventData.SetReturnData(hasOverrideOnSend, executionResult); } /// @@ -287,7 +436,7 @@ void OnSendEventHandler(object sender, CLRListenerEventArgs public virtual Org.Apache.Kafka.Clients.Producer.ProducerRecord OnSend(Org.Apache.Kafka.Clients.Producer.ProducerRecord arg0) { - return default; + hasOverrideOnSend = false; return default; } /// @@ -296,10 +445,13 @@ public virtual Org.Apache.Kafka.Clients.Producer.ProducerRecord OnSend(Org /// If has a value it takes precedence over corresponding class method public global::System.Action OnClose { get; set; } = null; - void CloseEventHandler(object sender, CLRListenerEventArgs data) + bool hasOverrideClose = true; + void CloseEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideClose = true; var methodToExecute = (OnClose != null) ? OnClose : Close; methodToExecute.Invoke(); + data.EventData.TypedEventData.HasOverride = hasOverrideClose; } /// @@ -307,7 +459,7 @@ void CloseEventHandler(object sender, CLRListenerEventArgs data) /// public virtual void Close() { - + hasOverrideClose = false; } /// @@ -316,10 +468,13 @@ public virtual void Close() /// If has a value it takes precedence over corresponding class method public global::System.Action OnOnAcknowledgement { get; set; } = null; - void OnAcknowledgementEventHandler(object sender, CLRListenerEventArgs> data) + bool hasOverrideOnAcknowledgement = true; + void OnAcknowledgementEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideOnAcknowledgement = true; var methodToExecute = (OnOnAcknowledgement != null) ? OnOnAcknowledgement : OnAcknowledgement; - methodToExecute.Invoke(data.EventData.TypedEventData, JVMBridgeException.New(data.EventData.ExtraData.Get(0) as MASES.JCOBridge.C2JBridge.JVMInterop.IJavaObject)); + methodToExecute.Invoke(data.EventData.GetAt(0), JVMBridgeException.New(data.EventData.ExtraData.Get(1) as MASES.JCOBridge.C2JBridge.JVMInterop.IJavaObject)); + data.EventData.TypedEventData.HasOverride = hasOverrideOnAcknowledgement; } /// @@ -329,7 +484,7 @@ void OnAcknowledgementEventHandler(object sender, CLRListenerEventArgs public virtual void OnAcknowledgement(Org.Apache.Kafka.Clients.Producer.RecordMetadata arg0, MASES.JCOBridge.C2JBridge.JVMBridgeException arg1) { - + hasOverrideOnAcknowledgement = false; } /// @@ -338,10 +493,13 @@ public virtual void OnAcknowledgement(Org.Apache.Kafka.Clients.Producer.RecordMe /// If has a value it takes precedence over corresponding class method public global::System.Action> OnConfigure { get; set; } = null; - void ConfigureEventHandler(object sender, CLRListenerEventArgs>> data) + bool hasOverrideConfigure = true; + void ConfigureEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideConfigure = true; var methodToExecute = (OnConfigure != null) ? OnConfigure : Configure; - methodToExecute.Invoke(data.EventData.TypedEventData); + methodToExecute.Invoke(data.EventData.GetAt>(0)); + data.EventData.TypedEventData.HasOverride = hasOverrideConfigure; } /// @@ -350,7 +508,7 @@ void ConfigureEventHandler(object sender, CLRListenerEventArgs public virtual void Configure(Java.Util.Map arg0) { - + hasOverrideConfigure = false; } #endregion @@ -363,7 +521,7 @@ public virtual void Configure(Java.Util.Map arg0) } #endregion - #region ProducerInterceptorDirect + #region ProducerInterceptorDirect implementation public partial class ProducerInterceptorDirect : Org.Apache.Kafka.Clients.Producer.IProducerInterceptor, Org.Apache.Kafka.Common.IConfigurable, Java.Lang.IAutoCloseable { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/ProducerRecord.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/ProducerRecord.cs index e8d48d7c5..c0f8ea050 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/ProducerRecord.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/ProducerRecord.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,99 @@ namespace Org.Apache.Kafka.Clients.Producer { - #region ProducerRecord + #region ProducerRecord declaration + /// + /// + /// + public partial class ProducerRecord : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.clients.producer.ProducerRecord"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ProducerRecord() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ProducerRecord(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 ProducerRecord declaration + /// + /// + /// + /// + /// + public partial class ProducerRecord : MASES.JCOBridge.C2JBridge.JVMBridgeBase> + { + const string _bridgeClassName = "org.apache.kafka.clients.producer.ProducerRecord"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ProducerRecord() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ProducerRecord(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 ProducerRecord implementation public partial class ProducerRecord { #region Constructors @@ -171,7 +263,7 @@ public object Value() } #endregion - #region ProducerRecord + #region ProducerRecord implementation public partial class ProducerRecord { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/RecordMetadata.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/RecordMetadata.cs index d60285828..94e5ee2e7 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/RecordMetadata.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/RecordMetadata.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.Producer { - #region RecordMetadata + #region RecordMetadata declaration + /// + /// + /// + public partial class RecordMetadata : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.clients.producer.RecordMetadata"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public RecordMetadata() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public RecordMetadata(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 RecordMetadata implementation public partial class RecordMetadata { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/RoundRobinPartitioner.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/RoundRobinPartitioner.cs index a1c7e28d1..4a7b9731a 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/RoundRobinPartitioner.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/RoundRobinPartitioner.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.Producer { - #region RoundRobinPartitioner + #region RoundRobinPartitioner declaration + /// + /// + /// + public partial class RoundRobinPartitioner : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.clients.producer.RoundRobinPartitioner"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public RoundRobinPartitioner() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public RoundRobinPartitioner(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 RoundRobinPartitioner implementation public partial class RoundRobinPartitioner { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/RequestCompletionHandler.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/RequestCompletionHandler.cs index e07ce3477..8dad3d7e9 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/RequestCompletionHandler.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/RequestCompletionHandler.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 { + #region RequestCompletionHandler declaration + /// + /// + /// + public partial class RequestCompletionHandler : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.clients.RequestCompletionHandler"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("RequestCompletionHandler 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 RequestCompletionHandler() { } + /// + /// 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("RequestCompletionHandler 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 RequestCompletionHandler(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 IRequestCompletionHandler /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +90,7 @@ public partial interface IRequestCompletionHandler } #endregion - #region RequestCompletionHandler + #region RequestCompletionHandler implementation public partial class RequestCompletionHandler : Org.Apache.Kafka.Clients.IRequestCompletionHandler { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/StaleMetadataException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/StaleMetadataException.cs index 2985183bf..b898c11d3 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/StaleMetadataException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/StaleMetadataException.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,24 @@ namespace Org.Apache.Kafka.Clients { - #region StaleMetadataException + #region StaleMetadataException declaration + /// + /// + /// + public partial class StaleMetadataException : Org.Apache.Kafka.Common.Errors.InvalidMetadataException + { + const string _bridgeClassName = "org.apache.kafka.clients.StaleMetadataException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region StaleMetadataException implementation public partial class StaleMetadataException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Acl/AccessControlEntry.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Acl/AccessControlEntry.cs index 8c222e19b..2a10328e7 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Acl/AccessControlEntry.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Acl/AccessControlEntry.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.Common.Acl { - #region AccessControlEntry + #region AccessControlEntry declaration + /// + /// + /// + public partial class AccessControlEntry : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.acl.AccessControlEntry"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public AccessControlEntry() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public AccessControlEntry(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 AccessControlEntry implementation public partial class AccessControlEntry { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Acl/AccessControlEntryFilter.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Acl/AccessControlEntryFilter.cs index 1130daf5b..515748a6f 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Acl/AccessControlEntryFilter.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Acl/AccessControlEntryFilter.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.Common.Acl { - #region AccessControlEntryFilter + #region AccessControlEntryFilter declaration + /// + /// + /// + public partial class AccessControlEntryFilter : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.acl.AccessControlEntryFilter"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public AccessControlEntryFilter() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public AccessControlEntryFilter(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 AccessControlEntryFilter implementation public partial class AccessControlEntryFilter { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Acl/AclBinding.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Acl/AclBinding.cs index effd8d5ce..cbfa42746 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Acl/AclBinding.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Acl/AclBinding.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.Common.Acl { - #region AclBinding + #region AclBinding declaration + /// + /// + /// + public partial class AclBinding : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.acl.AclBinding"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public AclBinding() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public AclBinding(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 AclBinding implementation public partial class AclBinding { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Acl/AclBindingFilter.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Acl/AclBindingFilter.cs index ca6b4e1b1..df7eaea3f 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Acl/AclBindingFilter.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Acl/AclBindingFilter.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.Common.Acl { - #region AclBindingFilter + #region AclBindingFilter declaration + /// + /// + /// + public partial class AclBindingFilter : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.acl.AclBindingFilter"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public AclBindingFilter() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public AclBindingFilter(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 AclBindingFilter implementation public partial class AclBindingFilter { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Acl/AclOperation.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Acl/AclOperation.cs index 753a16446..9bca74185 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Acl/AclOperation.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Acl/AclOperation.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.Common.Acl { - #region AclOperation + #region AclOperation declaration + /// + /// + /// + public partial class AclOperation : Java.Lang.Enum + { + const string _bridgeClassName = "org.apache.kafka.common.acl.AclOperation"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public AclOperation() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public AclOperation(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 AclOperation implementation public partial class AclOperation { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Acl/AclPermissionType.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Acl/AclPermissionType.cs index 9a5941150..f001e1900 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Acl/AclPermissionType.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Acl/AclPermissionType.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.Common.Acl { - #region AclPermissionType + #region AclPermissionType declaration + /// + /// + /// + public partial class AclPermissionType : Java.Lang.Enum + { + const string _bridgeClassName = "org.apache.kafka.common.acl.AclPermissionType"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public AclPermissionType() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public AclPermissionType(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 AclPermissionType implementation public partial class AclPermissionType { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Acl/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Acl/AllPackageClasses.cs deleted file mode 100644 index f53443083..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Acl/AllPackageClasses.cs +++ /dev/null @@ -1,301 +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.Common.Acl -{ - #region AccessControlEntry - /// - /// - /// - public partial class AccessControlEntry : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.acl.AccessControlEntry"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public AccessControlEntry() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public AccessControlEntry(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 AccessControlEntryFilter - /// - /// - /// - public partial class AccessControlEntryFilter : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.acl.AccessControlEntryFilter"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public AccessControlEntryFilter() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public AccessControlEntryFilter(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 AclBinding - /// - /// - /// - public partial class AclBinding : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.acl.AclBinding"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public AclBinding() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public AclBinding(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 AclBindingFilter - /// - /// - /// - public partial class AclBindingFilter : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.acl.AclBindingFilter"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public AclBindingFilter() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public AclBindingFilter(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 AclOperation - /// - /// - /// - public partial class AclOperation : Java.Lang.Enum - { - const string _bridgeClassName = "org.apache.kafka.common.acl.AclOperation"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public AclOperation() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public AclOperation(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 AclPermissionType - /// - /// - /// - public partial class AclPermissionType : Java.Lang.Enum - { - const string _bridgeClassName = "org.apache.kafka.common.acl.AclPermissionType"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public AclPermissionType() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public AclPermissionType(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/Common/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/AllPackageClasses.cs deleted file mode 100644 index a3684307e..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/AllPackageClasses.cs +++ /dev/null @@ -1,1419 +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.Common -{ - #region Cluster - /// - /// - /// - public partial class Cluster : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.Cluster"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Cluster() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Cluster(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 ClusterResource - /// - /// - /// - public partial class ClusterResource : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.ClusterResource"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ClusterResource() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ClusterResource(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 ClusterResourceListener - /// - /// - /// - public partial class ClusterResourceListener : MASES.JCOBridge.C2JBridge.JVMBridgeListener - { - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ClusterResourceListener() { InitializeHandlers(); } - - const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.common.ClusterResourceListener"; - 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; - - - // TODO: complete the class - - } - #endregion - - #region ClusterResourceListenerDirect - /// - /// Direct override of or its generic type if there is one - /// - public partial class ClusterResourceListenerDirect : ClusterResourceListener - { - /// - /// - /// - public override bool AutoInit => false; - - /// - protected override void InitializeHandlers() { } - - const string _bridgeClassName = "org.apache.kafka.common.ClusterResourceListener"; - 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; - } - #endregion - - #region Configurable - /// - /// - /// - public partial class Configurable : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.Configurable"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("Configurable 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 Configurable() { } - /// - /// 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("Configurable 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 Configurable(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 ConsumerGroupState - /// - /// - /// - public partial class ConsumerGroupState : Java.Lang.Enum - { - const string _bridgeClassName = "org.apache.kafka.common.ConsumerGroupState"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ConsumerGroupState() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ConsumerGroupState(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 ElectionType - /// - /// - /// - public partial class ElectionType : Java.Lang.Enum - { - const string _bridgeClassName = "org.apache.kafka.common.ElectionType"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ElectionType() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ElectionType(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 Endpoint - /// - /// - /// - public partial class Endpoint : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.Endpoint"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Endpoint() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Endpoint(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 InvalidRecordException - /// - /// - /// - public partial class InvalidRecordException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.InvalidRecordException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region IsolationLevel - /// - /// - /// - public partial class IsolationLevel : Java.Lang.Enum - { - const string _bridgeClassName = "org.apache.kafka.common.IsolationLevel"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public IsolationLevel() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public IsolationLevel(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 KafkaException - /// - /// - /// - public partial class KafkaException : Java.Lang.RuntimeException - { - const string _bridgeClassName = "org.apache.kafka.common.KafkaException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region KafkaFuture - /// - /// - /// - public partial class KafkaFuture : Java.Util.Concurrent.Future - { - const string _bridgeClassName = "org.apache.kafka.common.KafkaFuture"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("KafkaFuture 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 KafkaFuture() { } - /// - /// 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("KafkaFuture 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 KafkaFuture(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 - #region BaseFunction - /// - /// - /// - public partial class BaseFunction : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.KafkaFuture$BaseFunction"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("BaseFunction 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 BaseFunction() { } - /// - /// 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("BaseFunction 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 BaseFunction(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 BaseFunction - /// - /// - /// - /// - /// - public partial class BaseFunction : MASES.JCOBridge.C2JBridge.JVMBridgeBase> - { - const string _bridgeClassName = "org.apache.kafka.common.KafkaFuture$BaseFunction"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("BaseFunction 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 BaseFunction() { } - /// - /// 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("BaseFunction 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 BaseFunction(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 BiConsumer - /// - /// - /// - public partial class BiConsumer : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.KafkaFuture$BiConsumer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("BiConsumer 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 BiConsumer() { } - /// - /// 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("BiConsumer 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 BiConsumer(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 BiConsumer - /// - /// - /// - /// - /// - public partial class BiConsumer : MASES.JCOBridge.C2JBridge.JVMBridgeBase> - { - const string _bridgeClassName = "org.apache.kafka.common.KafkaFuture$BiConsumer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("BiConsumer 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 BiConsumer() { } - /// - /// 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("BiConsumer 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 BiConsumer(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 - - - } - #endregion - - #region KafkaFuture - /// - /// - /// - /// - public partial class KafkaFuture : Java.Util.Concurrent.Future - { - const string _bridgeClassName = "org.apache.kafka.common.KafkaFuture"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("KafkaFuture 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 KafkaFuture() { } - /// - /// 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("KafkaFuture 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 KafkaFuture(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 MessageFormatter - /// - /// - /// - public partial class MessageFormatter : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.MessageFormatter"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("MessageFormatter 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 MessageFormatter() { } - /// - /// 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("MessageFormatter 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 MessageFormatter(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 Metric - /// - /// - /// - public partial class Metric : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.Metric"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("Metric 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 Metric() { } - /// - /// 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("Metric 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 Metric(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 MetricName - /// - /// - /// - public partial class MetricName : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.MetricName"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public MetricName() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public MetricName(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 MetricNameTemplate - /// - /// - /// - public partial class MetricNameTemplate : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.MetricNameTemplate"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public MetricNameTemplate() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public MetricNameTemplate(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 Node - /// - /// - /// - public partial class Node : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.Node"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Node() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Node(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 PartitionInfo - /// - /// - /// - public partial class PartitionInfo : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.PartitionInfo"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public PartitionInfo() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public PartitionInfo(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 Reconfigurable - /// - /// - /// - public partial class Reconfigurable : Org.Apache.Kafka.Common.Configurable - { - const string _bridgeClassName = "org.apache.kafka.common.Reconfigurable"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("Reconfigurable 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 Reconfigurable() { } - /// - /// 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("Reconfigurable 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 Reconfigurable(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 TopicCollection - /// - /// - /// - public partial class TopicCollection : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.TopicCollection"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("TopicCollection 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 TopicCollection() { } - /// - /// 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("TopicCollection 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 TopicCollection(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 - #region TopicIdCollection - /// - /// - /// - public partial class TopicIdCollection : Org.Apache.Kafka.Common.TopicCollection - { - const string _bridgeClassName = "org.apache.kafka.common.TopicCollection$TopicIdCollection"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public TopicIdCollection() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public TopicIdCollection(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 TopicNameCollection - /// - /// - /// - public partial class TopicNameCollection : Org.Apache.Kafka.Common.TopicCollection - { - const string _bridgeClassName = "org.apache.kafka.common.TopicCollection$TopicNameCollection"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public TopicNameCollection() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public TopicNameCollection(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 TopicIdPartition - /// - /// - /// - public partial class TopicIdPartition : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.TopicIdPartition"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public TopicIdPartition() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public TopicIdPartition(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 TopicPartition - /// - /// - /// - public partial class TopicPartition : Java.Io.Serializable - { - const string _bridgeClassName = "org.apache.kafka.common.TopicPartition"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public TopicPartition() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public TopicPartition(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 TopicPartitionInfo - /// - /// - /// - public partial class TopicPartitionInfo : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.TopicPartitionInfo"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public TopicPartitionInfo() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public TopicPartitionInfo(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 TopicPartitionReplica - /// - /// - /// - public partial class TopicPartitionReplica : Java.Io.Serializable - { - const string _bridgeClassName = "org.apache.kafka.common.TopicPartitionReplica"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public TopicPartitionReplica() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public TopicPartitionReplica(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 Uuid - /// - /// - /// - public partial class Uuid : Java.Lang.Comparable - { - const string _bridgeClassName = "org.apache.kafka.common.Uuid"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Uuid() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Uuid(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/Common/Annotation/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Annotation/AllPackageClasses.cs deleted file mode 100644 index 884f46ced..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Annotation/AllPackageClasses.cs +++ /dev/null @@ -1,217 +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.Common.Annotation -{ - #region InterfaceStability - /// - /// - /// - public partial class InterfaceStability : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.annotation.InterfaceStability"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public InterfaceStability() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public InterfaceStability(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 Evolving - /// - /// - /// - public partial class Evolving : Java.Lang.Annotation.Annotation - { - const string _bridgeClassName = "org.apache.kafka.common.annotation.InterfaceStability$Evolving"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("Evolving 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 Evolving() { } - /// - /// 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("Evolving 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 Evolving(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 Stable - /// - /// - /// - public partial class Stable : Java.Lang.Annotation.Annotation - { - const string _bridgeClassName = "org.apache.kafka.common.annotation.InterfaceStability$Stable"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("Stable 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 Stable() { } - /// - /// 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("Stable 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 Stable(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 Unstable - /// - /// - /// - public partial class Unstable : Java.Lang.Annotation.Annotation - { - const string _bridgeClassName = "org.apache.kafka.common.annotation.InterfaceStability$Unstable"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("Unstable 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 Unstable() { } - /// - /// 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("Unstable 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 Unstable(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 - - - } - #endregion - - - -} \ No newline at end of file diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Annotation/InterfaceStability.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Annotation/InterfaceStability.cs index ec623ad55..640647a5a 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Annotation/InterfaceStability.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Annotation/InterfaceStability.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,193 @@ namespace Org.Apache.Kafka.Common.Annotation { - #region InterfaceStability + #region InterfaceStability declaration + /// + /// + /// + public partial class InterfaceStability : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.annotation.InterfaceStability"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public InterfaceStability() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public InterfaceStability(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 Evolving declaration + /// + /// + /// + public partial class Evolving : Java.Lang.Annotation.Annotation + { + const string _bridgeClassName = "org.apache.kafka.common.annotation.InterfaceStability$Evolving"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("Evolving 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 Evolving() { } + /// + /// 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("Evolving 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 Evolving(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 Stable declaration + /// + /// + /// + public partial class Stable : Java.Lang.Annotation.Annotation + { + const string _bridgeClassName = "org.apache.kafka.common.annotation.InterfaceStability$Stable"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("Stable 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 Stable() { } + /// + /// 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("Stable 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 Stable(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 Unstable declaration + /// + /// + /// + public partial class Unstable : Java.Lang.Annotation.Annotation + { + const string _bridgeClassName = "org.apache.kafka.common.annotation.InterfaceStability$Unstable"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("Unstable 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 Unstable() { } + /// + /// 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("Unstable 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 Unstable(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 + + + } + #endregion + + #region InterfaceStability implementation public partial class InterfaceStability { #region Constructors @@ -49,7 +235,7 @@ public partial class InterfaceStability #endregion #region Nested classes - #region Evolving + #region Evolving implementation public partial class Evolving { #region Constructors @@ -80,7 +266,7 @@ public partial class Evolving } #endregion - #region Stable + #region Stable implementation public partial class Stable { #region Constructors @@ -111,7 +297,7 @@ public partial class Stable } #endregion - #region Unstable + #region Unstable implementation public partial class Unstable { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Cache/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Cache/AllPackageClasses.cs deleted file mode 100644 index 22334c1bf..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Cache/AllPackageClasses.cs +++ /dev/null @@ -1,311 +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.Common.Cache -{ - #region Cache - /// - /// - /// - public partial class Cache : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.cache.Cache"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("Cache 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 Cache() { } - /// - /// 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("Cache 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 Cache(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 Cache - /// - /// - /// - /// - /// - public partial class Cache : MASES.JCOBridge.C2JBridge.JVMBridgeBase> - { - const string _bridgeClassName = "org.apache.kafka.common.cache.Cache"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("Cache 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 Cache() { } - /// - /// 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("Cache 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 Cache(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 LRUCache - /// - /// - /// - public partial class LRUCache : Org.Apache.Kafka.Common.Cache.Cache - { - const string _bridgeClassName = "org.apache.kafka.common.cache.LRUCache"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public LRUCache() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public LRUCache(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 LRUCache - /// - /// - /// - /// - /// - public partial class LRUCache : Org.Apache.Kafka.Common.Cache.Cache - { - const string _bridgeClassName = "org.apache.kafka.common.cache.LRUCache"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public LRUCache() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public LRUCache(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 SynchronizedCache - /// - /// - /// - public partial class SynchronizedCache : Org.Apache.Kafka.Common.Cache.Cache - { - const string _bridgeClassName = "org.apache.kafka.common.cache.SynchronizedCache"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public SynchronizedCache() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public SynchronizedCache(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 SynchronizedCache - /// - /// - /// - /// - /// - public partial class SynchronizedCache : Org.Apache.Kafka.Common.Cache.Cache - { - const string _bridgeClassName = "org.apache.kafka.common.cache.SynchronizedCache"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public SynchronizedCache() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public SynchronizedCache(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/Common/Cache/Cache.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Cache/Cache.cs index 4aa91a493..aa26bc5da 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Cache/Cache.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Cache/Cache.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,103 @@ namespace Org.Apache.Kafka.Common.Cache { - #region Cache + #region Cache declaration + /// + /// + /// + public partial class Cache : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.cache.Cache"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("Cache 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 Cache() { } + /// + /// 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("Cache 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 Cache(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 Cache declaration + /// + /// + /// + /// + /// + public partial class Cache : MASES.JCOBridge.C2JBridge.JVMBridgeBase> + { + const string _bridgeClassName = "org.apache.kafka.common.cache.Cache"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("Cache 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 Cache() { } + /// + /// 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("Cache 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 Cache(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 Cache implementation public partial class Cache { #region Constructors @@ -109,7 +205,7 @@ public partial interface ICache } #endregion - #region Cache + #region Cache implementation public partial class Cache : Org.Apache.Kafka.Common.Cache.ICache { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Cache/LRUCache.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Cache/LRUCache.cs index 363d572dc..7ed738f37 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Cache/LRUCache.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Cache/LRUCache.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,99 @@ namespace Org.Apache.Kafka.Common.Cache { - #region LRUCache + #region LRUCache declaration + /// + /// + /// + public partial class LRUCache : Org.Apache.Kafka.Common.Cache.Cache + { + const string _bridgeClassName = "org.apache.kafka.common.cache.LRUCache"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public LRUCache() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public LRUCache(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 LRUCache declaration + /// + /// + /// + /// + /// + public partial class LRUCache : Org.Apache.Kafka.Common.Cache.Cache + { + const string _bridgeClassName = "org.apache.kafka.common.cache.LRUCache"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public LRUCache() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public LRUCache(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 LRUCache implementation public partial class LRUCache { #region Constructors @@ -99,7 +191,7 @@ public void Put(object arg0, object arg1) } #endregion - #region LRUCache + #region LRUCache implementation public partial class LRUCache { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Cache/SynchronizedCache.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Cache/SynchronizedCache.cs index 4bf49cb60..447b23eea 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Cache/SynchronizedCache.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Cache/SynchronizedCache.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,99 @@ namespace Org.Apache.Kafka.Common.Cache { - #region SynchronizedCache + #region SynchronizedCache declaration + /// + /// + /// + public partial class SynchronizedCache : Org.Apache.Kafka.Common.Cache.Cache + { + const string _bridgeClassName = "org.apache.kafka.common.cache.SynchronizedCache"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public SynchronizedCache() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public SynchronizedCache(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 SynchronizedCache declaration + /// + /// + /// + /// + /// + public partial class SynchronizedCache : Org.Apache.Kafka.Common.Cache.Cache + { + const string _bridgeClassName = "org.apache.kafka.common.cache.SynchronizedCache"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public SynchronizedCache() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public SynchronizedCache(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 SynchronizedCache implementation public partial class SynchronizedCache { #region Constructors @@ -99,7 +191,7 @@ public void Put(object arg0, object arg1) } #endregion - #region SynchronizedCache + #region SynchronizedCache implementation public partial class SynchronizedCache { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Cluster.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Cluster.cs index 5ee36cf1c..43fae4cec 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Cluster.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Cluster.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.Common { - #region Cluster + #region Cluster declaration + /// + /// + /// + public partial class Cluster : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.Cluster"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Cluster() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Cluster(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 Cluster implementation public partial class Cluster { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/ClusterResource.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/ClusterResource.cs index 76481c98d..f45c56312 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/ClusterResource.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/ClusterResource.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.Common { - #region ClusterResource + #region ClusterResource declaration + /// + /// + /// + public partial class ClusterResource : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.ClusterResource"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ClusterResource() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ClusterResource(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 ClusterResource implementation public partial class ClusterResource { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/ClusterResourceListener.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/ClusterResourceListener.cs index 50d6b5941..e6236977d 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/ClusterResourceListener.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/ClusterResourceListener.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,73 @@ namespace Org.Apache.Kafka.Common { + #region ClusterResourceListener declaration + /// + /// + /// + public partial class ClusterResourceListener : MASES.JCOBridge.C2JBridge.JVMBridgeListener + { + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ClusterResourceListener() { InitializeHandlers(); } + + const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.common.ClusterResourceListener"; + private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = 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; + + + // TODO: complete the class + + } + #endregion + + #region ClusterResourceListenerDirect declaration + /// + /// Direct override of or its generic type if there is one + /// + public partial class ClusterResourceListenerDirect : ClusterResourceListener + { + /// + /// + /// + public override bool AutoInit => false; + + /// + protected override void InitializeHandlers() { } + + const string _bridgeClassName = "org.apache.kafka.common.ClusterResourceListener"; + 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; + } + #endregion + #region IClusterResourceListener /// /// .NET interface for org.mases.knet.generated.org.apache.kafka.common.ClusterResourceListener implementing @@ -43,7 +110,7 @@ public partial interface IClusterResourceListener } #endregion - #region ClusterResourceListener + #region ClusterResourceListener implementation public partial class ClusterResourceListener : Org.Apache.Kafka.Common.IClusterResourceListener { #region Constructors @@ -68,7 +135,7 @@ public partial class ClusterResourceListener : Org.Apache.Kafka.Common.IClusterR /// protected virtual void InitializeHandlers() { - AddEventHandler("onUpdate", new global::System.EventHandler>>(OnUpdateEventHandler)); + AddEventHandler("onUpdate", new global::System.EventHandler>>(OnUpdateEventHandler)); } @@ -78,10 +145,13 @@ protected virtual void InitializeHandlers() /// If has a value it takes precedence over corresponding class method public global::System.Action OnOnUpdate { get; set; } = null; - void OnUpdateEventHandler(object sender, CLRListenerEventArgs> data) + bool hasOverrideOnUpdate = true; + void OnUpdateEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideOnUpdate = true; var methodToExecute = (OnOnUpdate != null) ? OnOnUpdate : OnUpdate; - methodToExecute.Invoke(data.EventData.TypedEventData); + methodToExecute.Invoke(data.EventData.GetAt(0)); + data.EventData.TypedEventData.HasOverride = hasOverrideOnUpdate; } /// @@ -90,7 +160,7 @@ void OnUpdateEventHandler(object sender, CLRListenerEventArgs public virtual void OnUpdate(Org.Apache.Kafka.Common.ClusterResource arg0) { - + hasOverrideOnUpdate = false; } #endregion @@ -103,7 +173,7 @@ public virtual void OnUpdate(Org.Apache.Kafka.Common.ClusterResource arg0) } #endregion - #region ClusterResourceListenerDirect + #region ClusterResourceListenerDirect implementation public partial class ClusterResourceListenerDirect : Org.Apache.Kafka.Common.IClusterResourceListener { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Compress/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Compress/AllPackageClasses.cs deleted file mode 100644 index 203d8e576..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Compress/AllPackageClasses.cs +++ /dev/null @@ -1,301 +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.Common.Compress -{ - #region KafkaLZ4BlockInputStream - /// - /// - /// - public partial class KafkaLZ4BlockInputStream : Java.Io.InputStream - { - const string _bridgeClassName = "org.apache.kafka.common.compress.KafkaLZ4BlockInputStream"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public KafkaLZ4BlockInputStream() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public KafkaLZ4BlockInputStream(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 KafkaLZ4BlockOutputStream - /// - /// - /// - public partial class KafkaLZ4BlockOutputStream : Java.Io.OutputStream - { - const string _bridgeClassName = "org.apache.kafka.common.compress.KafkaLZ4BlockOutputStream"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public KafkaLZ4BlockOutputStream() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public KafkaLZ4BlockOutputStream(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 BD - /// - /// - /// - public partial class BD : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.compress.KafkaLZ4BlockOutputStream$BD"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public BD() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public BD(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 FLG - /// - /// - /// - public partial class FLG : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.compress.KafkaLZ4BlockOutputStream$FLG"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public FLG() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public FLG(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 SnappyFactory - /// - /// - /// - public partial class SnappyFactory : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.compress.SnappyFactory"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public SnappyFactory() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public SnappyFactory(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 ZstdFactory - /// - /// - /// - public partial class ZstdFactory : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.compress.ZstdFactory"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ZstdFactory() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ZstdFactory(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/Common/Compress/KafkaLZ4BlockInputStream.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Compress/KafkaLZ4BlockInputStream.cs index 786374957..97578078c 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Compress/KafkaLZ4BlockInputStream.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Compress/KafkaLZ4BlockInputStream.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.Common.Compress { - #region KafkaLZ4BlockInputStream + #region KafkaLZ4BlockInputStream declaration + /// + /// + /// + public partial class KafkaLZ4BlockInputStream : Java.Io.InputStream + { + const string _bridgeClassName = "org.apache.kafka.common.compress.KafkaLZ4BlockInputStream"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public KafkaLZ4BlockInputStream() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public KafkaLZ4BlockInputStream(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 KafkaLZ4BlockInputStream implementation public partial class KafkaLZ4BlockInputStream { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Compress/KafkaLZ4BlockOutputStream.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Compress/KafkaLZ4BlockOutputStream.cs index aa20df570..31525e97b 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Compress/KafkaLZ4BlockOutputStream.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Compress/KafkaLZ4BlockOutputStream.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,142 @@ namespace Org.Apache.Kafka.Common.Compress { - #region KafkaLZ4BlockOutputStream + #region KafkaLZ4BlockOutputStream declaration + /// + /// + /// + public partial class KafkaLZ4BlockOutputStream : Java.Io.OutputStream + { + const string _bridgeClassName = "org.apache.kafka.common.compress.KafkaLZ4BlockOutputStream"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public KafkaLZ4BlockOutputStream() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public KafkaLZ4BlockOutputStream(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 BD declaration + /// + /// + /// + public partial class BD : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.compress.KafkaLZ4BlockOutputStream$BD"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public BD() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public BD(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 FLG declaration + /// + /// + /// + public partial class FLG : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.compress.KafkaLZ4BlockOutputStream$FLG"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public FLG() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public FLG(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 KafkaLZ4BlockOutputStream implementation public partial class KafkaLZ4BlockOutputStream { #region Constructors @@ -157,7 +292,7 @@ public bool UseBrokenFlagDescriptorChecksum() #endregion #region Nested classes - #region BD + #region BD implementation public partial class BD { #region Constructors @@ -220,7 +355,7 @@ public byte ToByte() } #endregion - #region FLG + #region FLG implementation public partial class FLG { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Compress/SnappyFactory.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Compress/SnappyFactory.cs index 041bcbe19..76e1ca6bb 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Compress/SnappyFactory.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Compress/SnappyFactory.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.Common.Compress { - #region SnappyFactory + #region SnappyFactory declaration + /// + /// + /// + public partial class SnappyFactory : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.compress.SnappyFactory"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public SnappyFactory() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public SnappyFactory(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 SnappyFactory implementation public partial class SnappyFactory { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Compress/ZstdFactory.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Compress/ZstdFactory.cs index d872e49ea..d23108b87 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Compress/ZstdFactory.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Compress/ZstdFactory.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.Common.Compress { - #region ZstdFactory + #region ZstdFactory declaration + /// + /// + /// + public partial class ZstdFactory : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.compress.ZstdFactory"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ZstdFactory() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ZstdFactory(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 ZstdFactory implementation public partial class ZstdFactory { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/AbstractConfig.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/AbstractConfig.cs index 9dcd910b1..b97fd48f6 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/AbstractConfig.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/AbstractConfig.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.Common.Config { - #region AbstractConfig + #region AbstractConfig declaration + /// + /// + /// + public partial class AbstractConfig : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.config.AbstractConfig"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public AbstractConfig() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public AbstractConfig(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 AbstractConfig implementation public partial class AbstractConfig { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/AllPackageClasses.cs deleted file mode 100644 index f8f90dd37..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/AllPackageClasses.cs +++ /dev/null @@ -1,1514 +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.Common.Config -{ - #region AbstractConfig - /// - /// - /// - public partial class AbstractConfig : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.config.AbstractConfig"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public AbstractConfig() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public AbstractConfig(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.common.config.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 ConfigChangeCallback - /// - /// - /// - public partial class ConfigChangeCallback : MASES.JCOBridge.C2JBridge.JVMBridgeListener - { - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ConfigChangeCallback() { InitializeHandlers(); } - - const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.common.config.ConfigChangeCallback"; - 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; - - - // TODO: complete the class - - } - #endregion - - #region ConfigChangeCallbackDirect - /// - /// Direct override of or its generic type if there is one - /// - public partial class ConfigChangeCallbackDirect : ConfigChangeCallback - { - /// - /// - /// - public override bool AutoInit => false; - - /// - protected override void InitializeHandlers() { } - - const string _bridgeClassName = "org.apache.kafka.common.config.ConfigChangeCallback"; - 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; - } - #endregion - - #region ConfigData - /// - /// - /// - public partial class ConfigData : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.config.ConfigData"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ConfigData() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ConfigData(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 ConfigDef - /// - /// - /// - public partial class ConfigDef : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ConfigDef() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ConfigDef(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 CaseInsensitiveValidString - /// - /// - /// - public partial class CaseInsensitiveValidString : Org.Apache.Kafka.Common.Config.ConfigDef.Validator - { - const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$CaseInsensitiveValidString"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public CaseInsensitiveValidString() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public CaseInsensitiveValidString(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 CompositeValidator - /// - /// - /// - public partial class CompositeValidator : Org.Apache.Kafka.Common.Config.ConfigDef.Validator - { - const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$CompositeValidator"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public CompositeValidator() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public CompositeValidator(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 ConfigKey - /// - /// - /// - public partial class ConfigKey : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$ConfigKey"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ConfigKey() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ConfigKey(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 Importance - /// - /// - /// - public partial class Importance : Java.Lang.Enum - { - const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$Importance"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Importance() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Importance(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 LambdaValidator - /// - /// - /// - public partial class LambdaValidator : Org.Apache.Kafka.Common.Config.ConfigDef.Validator - { - const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$LambdaValidator"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public LambdaValidator() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public LambdaValidator(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 ListSize - /// - /// - /// - public partial class ListSize : Org.Apache.Kafka.Common.Config.ConfigDef.Validator - { - const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$ListSize"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ListSize() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ListSize(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 NonEmptyString - /// - /// - /// - public partial class NonEmptyString : Org.Apache.Kafka.Common.Config.ConfigDef.Validator - { - const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$NonEmptyString"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public NonEmptyString() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public NonEmptyString(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 NonEmptyStringWithoutControlChars - /// - /// - /// - public partial class NonEmptyStringWithoutControlChars : Org.Apache.Kafka.Common.Config.ConfigDef.Validator - { - const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$NonEmptyStringWithoutControlChars"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public NonEmptyStringWithoutControlChars() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public NonEmptyStringWithoutControlChars(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 NonNullValidator - /// - /// - /// - public partial class NonNullValidator : Org.Apache.Kafka.Common.Config.ConfigDef.Validator - { - const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$NonNullValidator"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public NonNullValidator() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public NonNullValidator(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 Range - /// - /// - /// - public partial class Range : Org.Apache.Kafka.Common.Config.ConfigDef.Validator - { - const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$Range"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Range() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Range(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 Recommender - /// - /// - /// - public partial class Recommender : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$Recommender"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("Recommender 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 Recommender() { } - /// - /// 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("Recommender 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 Recommender(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 Type - /// - /// - /// - public partial class Type : Java.Lang.Enum - { - const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$Type"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Type() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Type(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 Validator - /// - /// - /// - public partial class Validator : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$Validator"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("Validator 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 Validator() { } - /// - /// 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("Validator 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 Validator(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 ValidList - /// - /// - /// - public partial class ValidList : Org.Apache.Kafka.Common.Config.ConfigDef.Validator - { - const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$ValidList"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ValidList() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ValidList(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 ValidString - /// - /// - /// - public partial class ValidString : Org.Apache.Kafka.Common.Config.ConfigDef.Validator - { - const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$ValidString"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ValidString() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ValidString(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 Width - /// - /// - /// - public partial class Width : Java.Lang.Enum - { - const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$Width"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Width() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Width(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 ConfigException - /// - /// - /// - public partial class ConfigException : Org.Apache.Kafka.Common.KafkaException - { - const string _bridgeClassName = "org.apache.kafka.common.config.ConfigException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region ConfigResource - /// - /// - /// - public partial class ConfigResource : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.config.ConfigResource"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ConfigResource() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ConfigResource(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 Type - /// - /// - /// - public partial class Type : Java.Lang.Enum - { - const string _bridgeClassName = "org.apache.kafka.common.config.ConfigResource$Type"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Type() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Type(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 ConfigTransformer - /// - /// - /// - public partial class ConfigTransformer : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.config.ConfigTransformer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ConfigTransformer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ConfigTransformer(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 ConfigTransformerResult - /// - /// - /// - public partial class ConfigTransformerResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.config.ConfigTransformerResult"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ConfigTransformerResult() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ConfigTransformerResult(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 ConfigValue - /// - /// - /// - public partial class ConfigValue : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.config.ConfigValue"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ConfigValue() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ConfigValue(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 LogLevelConfig - /// - /// - /// - public partial class LogLevelConfig : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.config.LogLevelConfig"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public LogLevelConfig() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public LogLevelConfig(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 SaslConfigs - /// - /// - /// - public partial class SaslConfigs : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.config.SaslConfigs"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public SaslConfigs() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public SaslConfigs(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 SecurityConfig - /// - /// - /// - public partial class SecurityConfig : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.config.SecurityConfig"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public SecurityConfig() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public SecurityConfig(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 SslClientAuth - /// - /// - /// - public partial class SslClientAuth : Java.Lang.Enum - { - const string _bridgeClassName = "org.apache.kafka.common.config.SslClientAuth"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public SslClientAuth() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public SslClientAuth(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 SslConfigs - /// - /// - /// - public partial class SslConfigs : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.config.SslConfigs"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public SslConfigs() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public SslConfigs(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 TopicConfig - /// - /// - /// - public partial class TopicConfig : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.config.TopicConfig"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public TopicConfig() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public TopicConfig(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/Common/Config/Config.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/Config.cs index b7927a6d5..afc2a5cc9 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/Config.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/Config.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.Common.Config { - #region Config + #region Config declaration + /// + /// + /// + public partial class Config : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.config.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 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 Config implementation public partial class Config { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/ConfigChangeCallback.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/ConfigChangeCallback.cs index 9892fd6d6..e5c5f0026 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/ConfigChangeCallback.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/ConfigChangeCallback.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,73 @@ namespace Org.Apache.Kafka.Common.Config { + #region ConfigChangeCallback declaration + /// + /// + /// + public partial class ConfigChangeCallback : MASES.JCOBridge.C2JBridge.JVMBridgeListener + { + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ConfigChangeCallback() { InitializeHandlers(); } + + const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.common.config.ConfigChangeCallback"; + private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = 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; + + + // TODO: complete the class + + } + #endregion + + #region ConfigChangeCallbackDirect declaration + /// + /// Direct override of or its generic type if there is one + /// + public partial class ConfigChangeCallbackDirect : ConfigChangeCallback + { + /// + /// + /// + public override bool AutoInit => false; + + /// + protected override void InitializeHandlers() { } + + const string _bridgeClassName = "org.apache.kafka.common.config.ConfigChangeCallback"; + 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; + } + #endregion + #region IConfigChangeCallback /// /// .NET interface for org.mases.knet.generated.org.apache.kafka.common.config.ConfigChangeCallback implementing @@ -43,7 +110,7 @@ public partial interface IConfigChangeCallback } #endregion - #region ConfigChangeCallback + #region ConfigChangeCallback implementation public partial class ConfigChangeCallback : Org.Apache.Kafka.Common.Config.IConfigChangeCallback { #region Constructors @@ -68,7 +135,7 @@ public partial class ConfigChangeCallback : Org.Apache.Kafka.Common.Config.IConf /// protected virtual void InitializeHandlers() { - AddEventHandler("onChange", new global::System.EventHandler>>(OnChangeEventHandler)); + AddEventHandler("onChange", new global::System.EventHandler>>(OnChangeEventHandler)); } @@ -78,10 +145,13 @@ protected virtual void InitializeHandlers() /// If has a value it takes precedence over corresponding class method public global::System.Action OnOnChange { get; set; } = null; - void OnChangeEventHandler(object sender, CLRListenerEventArgs> data) + bool hasOverrideOnChange = true; + void OnChangeEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideOnChange = true; var methodToExecute = (OnOnChange != null) ? OnOnChange : OnChange; - methodToExecute.Invoke(data.EventData.TypedEventData, data.EventData.GetAt(0)); + methodToExecute.Invoke(data.EventData.GetAt(0), data.EventData.GetAt(1)); + data.EventData.TypedEventData.HasOverride = hasOverrideOnChange; } /// @@ -91,7 +161,7 @@ void OnChangeEventHandler(object sender, CLRListenerEventArgs public virtual void OnChange(Java.Lang.String arg0, Org.Apache.Kafka.Common.Config.ConfigData arg1) { - + hasOverrideOnChange = false; } #endregion @@ -104,7 +174,7 @@ public virtual void OnChange(Java.Lang.String arg0, Org.Apache.Kafka.Common.Conf } #endregion - #region ConfigChangeCallbackDirect + #region ConfigChangeCallbackDirect implementation public partial class ConfigChangeCallbackDirect : Org.Apache.Kafka.Common.Config.IConfigChangeCallback { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/ConfigData.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/ConfigData.cs index 66c332882..45acd16d7 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/ConfigData.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/ConfigData.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.Common.Config { - #region ConfigData + #region ConfigData declaration + /// + /// + /// + public partial class ConfigData : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.config.ConfigData"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ConfigData() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ConfigData(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 ConfigData implementation public partial class ConfigData { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/ConfigDef.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/ConfigDef.cs index 04e5fd6ad..fb018c0ac 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/ConfigDef.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/ConfigDef.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,776 @@ namespace Org.Apache.Kafka.Common.Config { - #region ConfigDef + #region ConfigDef declaration + /// + /// + /// + public partial class ConfigDef : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ConfigDef() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ConfigDef(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 CaseInsensitiveValidString declaration + /// + /// + /// + public partial class CaseInsensitiveValidString : Org.Apache.Kafka.Common.Config.ConfigDef.Validator + { + const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$CaseInsensitiveValidString"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public CaseInsensitiveValidString() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public CaseInsensitiveValidString(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 CompositeValidator declaration + /// + /// + /// + public partial class CompositeValidator : Org.Apache.Kafka.Common.Config.ConfigDef.Validator + { + const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$CompositeValidator"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public CompositeValidator() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public CompositeValidator(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 ConfigKey declaration + /// + /// + /// + public partial class ConfigKey : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$ConfigKey"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ConfigKey() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ConfigKey(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 Importance declaration + /// + /// + /// + public partial class Importance : Java.Lang.Enum + { + const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$Importance"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Importance() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Importance(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 LambdaValidator declaration + /// + /// + /// + public partial class LambdaValidator : Org.Apache.Kafka.Common.Config.ConfigDef.Validator + { + const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$LambdaValidator"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public LambdaValidator() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public LambdaValidator(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 ListSize declaration + /// + /// + /// + public partial class ListSize : Org.Apache.Kafka.Common.Config.ConfigDef.Validator + { + const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$ListSize"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ListSize() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ListSize(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 NonEmptyString declaration + /// + /// + /// + public partial class NonEmptyString : Org.Apache.Kafka.Common.Config.ConfigDef.Validator + { + const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$NonEmptyString"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public NonEmptyString() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public NonEmptyString(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 NonEmptyStringWithoutControlChars declaration + /// + /// + /// + public partial class NonEmptyStringWithoutControlChars : Org.Apache.Kafka.Common.Config.ConfigDef.Validator + { + const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$NonEmptyStringWithoutControlChars"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public NonEmptyStringWithoutControlChars() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public NonEmptyStringWithoutControlChars(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 NonNullValidator declaration + /// + /// + /// + public partial class NonNullValidator : Org.Apache.Kafka.Common.Config.ConfigDef.Validator + { + const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$NonNullValidator"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public NonNullValidator() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public NonNullValidator(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 Range declaration + /// + /// + /// + public partial class Range : Org.Apache.Kafka.Common.Config.ConfigDef.Validator + { + const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$Range"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Range() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Range(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 Recommender declaration + /// + /// + /// + public partial class Recommender : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$Recommender"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("Recommender 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 Recommender() { } + /// + /// 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("Recommender 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 Recommender(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 Type declaration + /// + /// + /// + public partial class Type : Java.Lang.Enum + { + const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$Type"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Type() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Type(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 Validator declaration + /// + /// + /// + public partial class Validator : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$Validator"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("Validator 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 Validator() { } + /// + /// 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("Validator 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 Validator(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 ValidList declaration + /// + /// + /// + public partial class ValidList : Org.Apache.Kafka.Common.Config.ConfigDef.Validator + { + const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$ValidList"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ValidList() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ValidList(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 ValidString declaration + /// + /// + /// + public partial class ValidString : Org.Apache.Kafka.Common.Config.ConfigDef.Validator + { + const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$ValidString"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ValidString() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ValidString(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 Width declaration + /// + /// + /// + public partial class Width : Java.Lang.Enum + { + const string _bridgeClassName = "org.apache.kafka.common.config.ConfigDef$Width"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Width() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Width(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 ConfigDef implementation public partial class ConfigDef { #region Constructors @@ -540,7 +1309,7 @@ public void Embed(Java.Lang.String arg0, Java.Lang.String arg1, int arg2, Org.Ap #endregion #region Nested classes - #region CaseInsensitiveValidString + #region CaseInsensitiveValidString implementation public partial class CaseInsensitiveValidString { #region Constructors @@ -589,7 +1358,7 @@ public void EnsureValid(Java.Lang.String arg0, object arg1) } #endregion - #region CompositeValidator + #region CompositeValidator implementation public partial class CompositeValidator { #region Constructors @@ -638,7 +1407,7 @@ public void EnsureValid(Java.Lang.String arg0, object arg1) } #endregion - #region ConfigKey + #region ConfigKey implementation public partial class ConfigKey { #region Constructors @@ -783,7 +1552,7 @@ public Org.Apache.Kafka.Common.Config.ConfigDef.Type TypeMethod() } #endregion - #region Importance + #region Importance implementation public partial class Importance { #region Constructors @@ -849,7 +1618,7 @@ public static Org.Apache.Kafka.Common.Config.ConfigDef.Importance[] Values() } #endregion - #region LambdaValidator + #region LambdaValidator implementation public partial class LambdaValidator { #region Constructors @@ -899,7 +1668,7 @@ public void EnsureValid(Java.Lang.String arg0, object arg1) } #endregion - #region ListSize + #region ListSize implementation public partial class ListSize { #region Constructors @@ -948,7 +1717,7 @@ public void EnsureValid(Java.Lang.String arg0, object arg1) } #endregion - #region NonEmptyString + #region NonEmptyString implementation public partial class NonEmptyString { #region Constructors @@ -988,7 +1757,7 @@ public void EnsureValid(Java.Lang.String arg0, object arg1) } #endregion - #region NonEmptyStringWithoutControlChars + #region NonEmptyStringWithoutControlChars implementation public partial class NonEmptyStringWithoutControlChars { #region Constructors @@ -1036,7 +1805,7 @@ public void EnsureValid(Java.Lang.String arg0, object arg1) } #endregion - #region NonNullValidator + #region NonNullValidator implementation public partial class NonNullValidator { #region Constructors @@ -1076,7 +1845,7 @@ public void EnsureValid(Java.Lang.String arg0, object arg1) } #endregion - #region Range + #region Range implementation public partial class Range { #region Constructors @@ -1135,7 +1904,7 @@ public void EnsureValid(Java.Lang.String arg0, object arg1) } #endregion - #region Recommender + #region Recommender implementation public partial class Recommender { #region Constructors @@ -1186,7 +1955,7 @@ public Java.Util.List ValidValues(Java.Lang.String arg0, Java.Util.Map + /// + /// + public partial class ConfigException : Org.Apache.Kafka.Common.KafkaException + { + const string _bridgeClassName = "org.apache.kafka.common.config.ConfigException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region ConfigException implementation public partial class ConfigException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/ConfigResource.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/ConfigResource.cs index f64aa65e7..5e66719dd 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/ConfigResource.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/ConfigResource.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.Common.Config { - #region ConfigResource + #region ConfigResource declaration + /// + /// + /// + public partial class ConfigResource : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.config.ConfigResource"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ConfigResource() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ConfigResource(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 Type declaration + /// + /// + /// + public partial class Type : Java.Lang.Enum + { + const string _bridgeClassName = "org.apache.kafka.common.config.ConfigResource$Type"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Type() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Type(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 ConfigResource implementation public partial class ConfigResource { #region Constructors @@ -82,7 +172,7 @@ public Org.Apache.Kafka.Common.Config.ConfigResource.Type TypeMethod() #endregion #region Nested classes - #region Type + #region Type implementation public partial class Type { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/ConfigTransformer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/ConfigTransformer.cs index c663da5c0..203f1980d 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/ConfigTransformer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/ConfigTransformer.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.Common.Config { - #region ConfigTransformer + #region ConfigTransformer declaration + /// + /// + /// + public partial class ConfigTransformer : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.config.ConfigTransformer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ConfigTransformer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ConfigTransformer(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 ConfigTransformer implementation public partial class ConfigTransformer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/ConfigTransformerResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/ConfigTransformerResult.cs index b337b6c33..854e877c5 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/ConfigTransformerResult.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/ConfigTransformerResult.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.Common.Config { - #region ConfigTransformerResult + #region ConfigTransformerResult declaration + /// + /// + /// + public partial class ConfigTransformerResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.config.ConfigTransformerResult"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ConfigTransformerResult() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ConfigTransformerResult(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 ConfigTransformerResult implementation public partial class ConfigTransformerResult { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/ConfigValue.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/ConfigValue.cs index 35ac8ed3d..2ef2a45dd 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/ConfigValue.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/ConfigValue.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.Common.Config { - #region ConfigValue + #region ConfigValue declaration + /// + /// + /// + public partial class ConfigValue : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.config.ConfigValue"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ConfigValue() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ConfigValue(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 ConfigValue implementation public partial class ConfigValue { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/LogLevelConfig.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/LogLevelConfig.cs index fe66fff3d..3ee761cc1 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/LogLevelConfig.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/LogLevelConfig.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.Common.Config { - #region LogLevelConfig + #region LogLevelConfig declaration + /// + /// + /// + public partial class LogLevelConfig : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.config.LogLevelConfig"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public LogLevelConfig() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public LogLevelConfig(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 LogLevelConfig implementation public partial class LogLevelConfig { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/Provider/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/Provider/AllPackageClasses.cs deleted file mode 100644 index a48c8a6dd..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/Provider/AllPackageClasses.cs +++ /dev/null @@ -1,213 +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.Common.Config.Provider -{ - #region ConfigProvider - /// - /// - /// - public partial class ConfigProvider : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.config.provider.ConfigProvider"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("ConfigProvider 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 ConfigProvider() { } - /// - /// 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("ConfigProvider 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 ConfigProvider(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 DirectoryConfigProvider - /// - /// - /// - public partial class DirectoryConfigProvider : Org.Apache.Kafka.Common.Config.Provider.ConfigProvider - { - const string _bridgeClassName = "org.apache.kafka.common.config.provider.DirectoryConfigProvider"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public DirectoryConfigProvider() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public DirectoryConfigProvider(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 EnvVarConfigProvider - /// - /// - /// - public partial class EnvVarConfigProvider : Org.Apache.Kafka.Common.Config.Provider.ConfigProvider - { - const string _bridgeClassName = "org.apache.kafka.common.config.provider.EnvVarConfigProvider"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public EnvVarConfigProvider() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public EnvVarConfigProvider(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 FileConfigProvider - /// - /// - /// - public partial class FileConfigProvider : Org.Apache.Kafka.Common.Config.Provider.ConfigProvider - { - const string _bridgeClassName = "org.apache.kafka.common.config.provider.FileConfigProvider"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public FileConfigProvider() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public FileConfigProvider(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/Common/Config/Provider/ConfigProvider.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/Provider/ConfigProvider.cs index a696231d1..356acc500 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/Provider/ConfigProvider.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/Provider/ConfigProvider.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.Common.Config.Provider { + #region ConfigProvider declaration + /// + /// + /// + public partial class ConfigProvider : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.config.provider.ConfigProvider"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("ConfigProvider 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 ConfigProvider() { } + /// + /// 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("ConfigProvider 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 ConfigProvider(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 IConfigProvider /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +90,7 @@ public partial interface IConfigProvider } #endregion - #region ConfigProvider + #region ConfigProvider implementation public partial class ConfigProvider : Org.Apache.Kafka.Common.Config.Provider.IConfigProvider, Org.Apache.Kafka.Common.IConfigurable, Java.Io.ICloseable { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/Provider/DirectoryConfigProvider.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/Provider/DirectoryConfigProvider.cs index 162dd4554..06fb9fb15 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/Provider/DirectoryConfigProvider.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/Provider/DirectoryConfigProvider.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.Common.Config.Provider { - #region DirectoryConfigProvider + #region DirectoryConfigProvider declaration + /// + /// + /// + public partial class DirectoryConfigProvider : Org.Apache.Kafka.Common.Config.Provider.ConfigProvider + { + const string _bridgeClassName = "org.apache.kafka.common.config.provider.DirectoryConfigProvider"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public DirectoryConfigProvider() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public DirectoryConfigProvider(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 DirectoryConfigProvider implementation public partial class DirectoryConfigProvider { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/Provider/EnvVarConfigProvider.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/Provider/EnvVarConfigProvider.cs index 76c051c5a..b2f5b6737 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/Provider/EnvVarConfigProvider.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/Provider/EnvVarConfigProvider.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.Common.Config.Provider { - #region EnvVarConfigProvider + #region EnvVarConfigProvider declaration + /// + /// + /// + public partial class EnvVarConfigProvider : Org.Apache.Kafka.Common.Config.Provider.ConfigProvider + { + const string _bridgeClassName = "org.apache.kafka.common.config.provider.EnvVarConfigProvider"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public EnvVarConfigProvider() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public EnvVarConfigProvider(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 EnvVarConfigProvider implementation public partial class EnvVarConfigProvider { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/Provider/FileConfigProvider.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/Provider/FileConfigProvider.cs index 26147ea9c..bf9f6df4d 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/Provider/FileConfigProvider.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/Provider/FileConfigProvider.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.Common.Config.Provider { - #region FileConfigProvider + #region FileConfigProvider declaration + /// + /// + /// + public partial class FileConfigProvider : Org.Apache.Kafka.Common.Config.Provider.ConfigProvider + { + const string _bridgeClassName = "org.apache.kafka.common.config.provider.FileConfigProvider"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public FileConfigProvider() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public FileConfigProvider(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 FileConfigProvider implementation public partial class FileConfigProvider { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/SaslConfigs.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/SaslConfigs.cs index 324871c4a..09b98438a 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/SaslConfigs.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/SaslConfigs.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.Common.Config { - #region SaslConfigs + #region SaslConfigs declaration + /// + /// + /// + public partial class SaslConfigs : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.config.SaslConfigs"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public SaslConfigs() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public SaslConfigs(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 SaslConfigs implementation public partial class SaslConfigs { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/SecurityConfig.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/SecurityConfig.cs index 978733ca9..5a7f8bcb4 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/SecurityConfig.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/SecurityConfig.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.Common.Config { - #region SecurityConfig + #region SecurityConfig declaration + /// + /// + /// + public partial class SecurityConfig : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.config.SecurityConfig"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public SecurityConfig() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public SecurityConfig(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 SecurityConfig implementation public partial class SecurityConfig { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/SslClientAuth.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/SslClientAuth.cs index cdf2c95dd..4be0637ea 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/SslClientAuth.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/SslClientAuth.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.Common.Config { - #region SslClientAuth + #region SslClientAuth declaration + /// + /// + /// + public partial class SslClientAuth : Java.Lang.Enum + { + const string _bridgeClassName = "org.apache.kafka.common.config.SslClientAuth"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public SslClientAuth() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public SslClientAuth(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 SslClientAuth implementation public partial class SslClientAuth { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/SslConfigs.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/SslConfigs.cs index 470a551d7..e0ef8e58c 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/SslConfigs.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/SslConfigs.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.Common.Config { - #region SslConfigs + #region SslConfigs declaration + /// + /// + /// + public partial class SslConfigs : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.config.SslConfigs"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public SslConfigs() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public SslConfigs(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 SslConfigs implementation public partial class SslConfigs { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/TopicConfig.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/TopicConfig.cs index 5b4453356..558627252 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/TopicConfig.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/TopicConfig.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.Common.Config { - #region TopicConfig + #region TopicConfig declaration + /// + /// + /// + public partial class TopicConfig : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.config.TopicConfig"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public TopicConfig() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public TopicConfig(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 TopicConfig implementation public partial class TopicConfig { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/Types/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/Types/AllPackageClasses.cs deleted file mode 100644 index 4dc0da035..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/Types/AllPackageClasses.cs +++ /dev/null @@ -1,76 +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.Common.Config.Types -{ - #region Password - /// - /// - /// - public partial class Password : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.config.types.Password"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Password() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Password(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/Common/Config/Types/Password.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/Types/Password.cs index d073d6865..9b43489f4 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/Types/Password.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/Types/Password.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.Common.Config.Types { - #region Password + #region Password declaration + /// + /// + /// + public partial class Password : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.config.types.Password"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Password() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Password(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 Password implementation public partial class Password { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Configurable.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Configurable.cs index aba14cb17..678f4ae8a 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Configurable.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Configurable.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.Common { + #region Configurable declaration + /// + /// + /// + public partial class Configurable : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.Configurable"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("Configurable 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 Configurable() { } + /// + /// 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("Configurable 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 Configurable(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 IConfigurable /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +90,7 @@ public partial interface IConfigurable } #endregion - #region Configurable + #region Configurable implementation public partial class Configurable : Org.Apache.Kafka.Common.IConfigurable { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/ConsumerGroupState.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/ConsumerGroupState.cs index f1ed87c86..fe180c432 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/ConsumerGroupState.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/ConsumerGroupState.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.Common { - #region ConsumerGroupState + #region ConsumerGroupState declaration + /// + /// + /// + public partial class ConsumerGroupState : Java.Lang.Enum + { + const string _bridgeClassName = "org.apache.kafka.common.ConsumerGroupState"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ConsumerGroupState() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ConsumerGroupState(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 ConsumerGroupState implementation public partial class ConsumerGroupState { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/ElectionType.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/ElectionType.cs index 218fde63b..ca2e61975 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/ElectionType.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/ElectionType.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.Common { - #region ElectionType + #region ElectionType declaration + /// + /// + /// + public partial class ElectionType : Java.Lang.Enum + { + const string _bridgeClassName = "org.apache.kafka.common.ElectionType"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ElectionType() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ElectionType(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 ElectionType implementation public partial class ElectionType { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Endpoint.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Endpoint.cs index f552e8d16..3fefaf9ca 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Endpoint.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Endpoint.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.Common { - #region Endpoint + #region Endpoint declaration + /// + /// + /// + public partial class Endpoint : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.Endpoint"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Endpoint() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Endpoint(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 Endpoint implementation public partial class Endpoint { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/AllPackageClasses.cs deleted file mode 100644 index 39b5c433a..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/AllPackageClasses.cs +++ /dev/null @@ -1,2190 +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.Common.Errors -{ - #region ApiException - /// - /// - /// - public partial class ApiException : Org.Apache.Kafka.Common.KafkaException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.ApiException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region AuthenticationException - /// - /// - /// - public partial class AuthenticationException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.AuthenticationException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region AuthorizationException - /// - /// - /// - public partial class AuthorizationException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.AuthorizationException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region AuthorizerNotReadyException - /// - /// - /// - public partial class AuthorizerNotReadyException : Org.Apache.Kafka.Common.Errors.RetriableException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.AuthorizerNotReadyException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region BrokerIdNotRegisteredException - /// - /// - /// - public partial class BrokerIdNotRegisteredException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.BrokerIdNotRegisteredException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region BrokerNotAvailableException - /// - /// - /// - public partial class BrokerNotAvailableException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.BrokerNotAvailableException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region ClusterAuthorizationException - /// - /// - /// - public partial class ClusterAuthorizationException : Org.Apache.Kafka.Common.Errors.AuthorizationException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.ClusterAuthorizationException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region ConcurrentTransactionsException - /// - /// - /// - public partial class ConcurrentTransactionsException : Org.Apache.Kafka.Common.Errors.RetriableException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.ConcurrentTransactionsException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region ControllerMovedException - /// - /// - /// - public partial class ControllerMovedException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.ControllerMovedException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region CoordinatorLoadInProgressException - /// - /// - /// - public partial class CoordinatorLoadInProgressException : Org.Apache.Kafka.Common.Errors.RetriableException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.CoordinatorLoadInProgressException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region CoordinatorNotAvailableException - /// - /// - /// - public partial class CoordinatorNotAvailableException : Org.Apache.Kafka.Common.Errors.RetriableException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.CoordinatorNotAvailableException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region CorruptRecordException - /// - /// - /// - public partial class CorruptRecordException : Org.Apache.Kafka.Common.Errors.RetriableException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.CorruptRecordException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region DelegationTokenAuthorizationException - /// - /// - /// - public partial class DelegationTokenAuthorizationException : Org.Apache.Kafka.Common.Errors.AuthorizationException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.DelegationTokenAuthorizationException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region DelegationTokenDisabledException - /// - /// - /// - public partial class DelegationTokenDisabledException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.DelegationTokenDisabledException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region DelegationTokenExpiredException - /// - /// - /// - public partial class DelegationTokenExpiredException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.DelegationTokenExpiredException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region DelegationTokenNotFoundException - /// - /// - /// - public partial class DelegationTokenNotFoundException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.DelegationTokenNotFoundException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region DelegationTokenOwnerMismatchException - /// - /// - /// - public partial class DelegationTokenOwnerMismatchException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.DelegationTokenOwnerMismatchException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region DisconnectException - /// - /// - /// - public partial class DisconnectException : Org.Apache.Kafka.Common.Errors.RetriableException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.DisconnectException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region DuplicateBrokerRegistrationException - /// - /// - /// - public partial class DuplicateBrokerRegistrationException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.DuplicateBrokerRegistrationException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region DuplicateResourceException - /// - /// - /// - public partial class DuplicateResourceException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.DuplicateResourceException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region DuplicateSequenceException - /// - /// - /// - public partial class DuplicateSequenceException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.DuplicateSequenceException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region ElectionNotNeededException - /// - /// - /// - public partial class ElectionNotNeededException : Org.Apache.Kafka.Common.Errors.InvalidMetadataException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.ElectionNotNeededException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region EligibleLeadersNotAvailableException - /// - /// - /// - public partial class EligibleLeadersNotAvailableException : Org.Apache.Kafka.Common.Errors.InvalidMetadataException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.EligibleLeadersNotAvailableException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region FeatureUpdateFailedException - /// - /// - /// - public partial class FeatureUpdateFailedException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.FeatureUpdateFailedException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region FencedInstanceIdException - /// - /// - /// - public partial class FencedInstanceIdException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.FencedInstanceIdException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region FencedLeaderEpochException - /// - /// - /// - public partial class FencedLeaderEpochException : Org.Apache.Kafka.Common.Errors.InvalidMetadataException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.FencedLeaderEpochException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region FencedMemberEpochException - /// - /// - /// - public partial class FencedMemberEpochException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.FencedMemberEpochException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region FetchSessionIdNotFoundException - /// - /// - /// - public partial class FetchSessionIdNotFoundException : Org.Apache.Kafka.Common.Errors.RetriableException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.FetchSessionIdNotFoundException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region FetchSessionTopicIdException - /// - /// - /// - public partial class FetchSessionTopicIdException : Org.Apache.Kafka.Common.Errors.RetriableException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.FetchSessionTopicIdException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region GroupAuthorizationException - /// - /// - /// - public partial class GroupAuthorizationException : Org.Apache.Kafka.Common.Errors.AuthorizationException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.GroupAuthorizationException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region GroupIdNotFoundException - /// - /// - /// - public partial class GroupIdNotFoundException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.GroupIdNotFoundException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region GroupMaxSizeReachedException - /// - /// - /// - public partial class GroupMaxSizeReachedException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.GroupMaxSizeReachedException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region GroupNotEmptyException - /// - /// - /// - public partial class GroupNotEmptyException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.GroupNotEmptyException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region GroupSubscribedToTopicException - /// - /// - /// - public partial class GroupSubscribedToTopicException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.GroupSubscribedToTopicException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region IllegalGenerationException - /// - /// - /// - public partial class IllegalGenerationException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.IllegalGenerationException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region IllegalSaslStateException - /// - /// - /// - public partial class IllegalSaslStateException : Org.Apache.Kafka.Common.Errors.AuthenticationException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.IllegalSaslStateException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region InconsistentClusterIdException - /// - /// - /// - public partial class InconsistentClusterIdException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.InconsistentClusterIdException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region InconsistentGroupProtocolException - /// - /// - /// - public partial class InconsistentGroupProtocolException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.InconsistentGroupProtocolException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region InconsistentTopicIdException - /// - /// - /// - public partial class InconsistentTopicIdException : Org.Apache.Kafka.Common.Errors.InvalidMetadataException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.InconsistentTopicIdException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region InconsistentVoterSetException - /// - /// - /// - public partial class InconsistentVoterSetException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.InconsistentVoterSetException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region IneligibleReplicaException - /// - /// - /// - public partial class IneligibleReplicaException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.IneligibleReplicaException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region InterruptException - /// - /// - /// - public partial class InterruptException : Org.Apache.Kafka.Common.KafkaException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.InterruptException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region InvalidCommitOffsetSizeException - /// - /// - /// - public partial class InvalidCommitOffsetSizeException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidCommitOffsetSizeException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region InvalidConfigurationException - /// - /// - /// - public partial class InvalidConfigurationException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidConfigurationException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region InvalidFetchSessionEpochException - /// - /// - /// - public partial class InvalidFetchSessionEpochException : Org.Apache.Kafka.Common.Errors.RetriableException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidFetchSessionEpochException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region InvalidFetchSizeException - /// - /// - /// - public partial class InvalidFetchSizeException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidFetchSizeException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region InvalidGroupIdException - /// - /// - /// - public partial class InvalidGroupIdException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidGroupIdException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region InvalidMetadataException - /// - /// - /// - public partial class InvalidMetadataException : Org.Apache.Kafka.Common.Errors.RetriableException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidMetadataException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region InvalidOffsetException - /// - /// - /// - public partial class InvalidOffsetException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidOffsetException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region InvalidPartitionsException - /// - /// - /// - public partial class InvalidPartitionsException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidPartitionsException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region InvalidPidMappingException - /// - /// - /// - public partial class InvalidPidMappingException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidPidMappingException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region InvalidPrincipalTypeException - /// - /// - /// - public partial class InvalidPrincipalTypeException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidPrincipalTypeException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region InvalidProducerEpochException - /// - /// - /// - public partial class InvalidProducerEpochException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidProducerEpochException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region InvalidReplicaAssignmentException - /// - /// - /// - public partial class InvalidReplicaAssignmentException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidReplicaAssignmentException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region InvalidReplicationFactorException - /// - /// - /// - public partial class InvalidReplicationFactorException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidReplicationFactorException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region InvalidRequestException - /// - /// - /// - public partial class InvalidRequestException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidRequestException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region InvalidRequiredAcksException - /// - /// - /// - public partial class InvalidRequiredAcksException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidRequiredAcksException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region InvalidSessionTimeoutException - /// - /// - /// - public partial class InvalidSessionTimeoutException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidSessionTimeoutException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region InvalidTimestampException - /// - /// - /// - public partial class InvalidTimestampException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidTimestampException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region InvalidTopicException - /// - /// - /// - public partial class InvalidTopicException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidTopicException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region InvalidTxnStateException - /// - /// - /// - public partial class InvalidTxnStateException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidTxnStateException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region InvalidTxnTimeoutException - /// - /// - /// - public partial class InvalidTxnTimeoutException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidTxnTimeoutException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region InvalidUpdateVersionException - /// - /// - /// - public partial class InvalidUpdateVersionException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidUpdateVersionException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region KafkaStorageException - /// - /// - /// - public partial class KafkaStorageException : Org.Apache.Kafka.Common.Errors.InvalidMetadataException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.KafkaStorageException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region LeaderNotAvailableException - /// - /// - /// - public partial class LeaderNotAvailableException : Org.Apache.Kafka.Common.Errors.InvalidMetadataException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.LeaderNotAvailableException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region ListenerNotFoundException - /// - /// - /// - public partial class ListenerNotFoundException : Org.Apache.Kafka.Common.Errors.InvalidMetadataException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.ListenerNotFoundException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region LogDirNotFoundException - /// - /// - /// - public partial class LogDirNotFoundException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.LogDirNotFoundException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region MemberIdRequiredException - /// - /// - /// - public partial class MemberIdRequiredException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.MemberIdRequiredException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region NetworkException - /// - /// - /// - public partial class NetworkException : Org.Apache.Kafka.Common.Errors.InvalidMetadataException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.NetworkException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region NewLeaderElectedException - /// - /// - /// - public partial class NewLeaderElectedException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.NewLeaderElectedException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region NoReassignmentInProgressException - /// - /// - /// - public partial class NoReassignmentInProgressException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.NoReassignmentInProgressException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region NotControllerException - /// - /// - /// - public partial class NotControllerException : Org.Apache.Kafka.Common.Errors.RetriableException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.NotControllerException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region NotCoordinatorException - /// - /// - /// - public partial class NotCoordinatorException : Org.Apache.Kafka.Common.Errors.RetriableException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.NotCoordinatorException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region NotEnoughReplicasAfterAppendException - /// - /// - /// - public partial class NotEnoughReplicasAfterAppendException : Org.Apache.Kafka.Common.Errors.RetriableException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.NotEnoughReplicasAfterAppendException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region NotEnoughReplicasException - /// - /// - /// - public partial class NotEnoughReplicasException : Org.Apache.Kafka.Common.Errors.RetriableException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.NotEnoughReplicasException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region NotLeaderOrFollowerException - /// - /// - /// - public partial class NotLeaderOrFollowerException : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.errors.NotLeaderOrFollowerException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region OffsetMetadataTooLarge - /// - /// - /// - public partial class OffsetMetadataTooLarge : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.OffsetMetadataTooLarge"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region OffsetMovedToTieredStorageException - /// - /// - /// - public partial class OffsetMovedToTieredStorageException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.OffsetMovedToTieredStorageException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region OffsetNotAvailableException - /// - /// - /// - public partial class OffsetNotAvailableException : Org.Apache.Kafka.Common.Errors.RetriableException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.OffsetNotAvailableException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region OffsetOutOfRangeException - /// - /// - /// - public partial class OffsetOutOfRangeException : Org.Apache.Kafka.Common.Errors.InvalidOffsetException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.OffsetOutOfRangeException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region OperationNotAttemptedException - /// - /// - /// - public partial class OperationNotAttemptedException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.OperationNotAttemptedException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region OutOfOrderSequenceException - /// - /// - /// - public partial class OutOfOrderSequenceException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.OutOfOrderSequenceException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region PolicyViolationException - /// - /// - /// - public partial class PolicyViolationException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.PolicyViolationException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region PositionOutOfRangeException - /// - /// - /// - public partial class PositionOutOfRangeException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.PositionOutOfRangeException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region PreferredLeaderNotAvailableException - /// - /// - /// - public partial class PreferredLeaderNotAvailableException : Org.Apache.Kafka.Common.Errors.InvalidMetadataException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.PreferredLeaderNotAvailableException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region PrincipalDeserializationException - /// - /// - /// - public partial class PrincipalDeserializationException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.PrincipalDeserializationException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region ProducerFencedException - /// - /// - /// - public partial class ProducerFencedException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.ProducerFencedException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region ReassignmentInProgressException - /// - /// - /// - public partial class ReassignmentInProgressException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.ReassignmentInProgressException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region RebalanceInProgressException - /// - /// - /// - public partial class RebalanceInProgressException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.RebalanceInProgressException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region RecordBatchTooLargeException - /// - /// - /// - public partial class RecordBatchTooLargeException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.RecordBatchTooLargeException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region RecordDeserializationException - /// - /// - /// - public partial class RecordDeserializationException : Org.Apache.Kafka.Common.Errors.SerializationException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.RecordDeserializationException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region RecordTooLargeException - /// - /// - /// - public partial class RecordTooLargeException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.RecordTooLargeException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region ReplicaNotAvailableException - /// - /// - /// - public partial class ReplicaNotAvailableException : Org.Apache.Kafka.Common.Errors.InvalidMetadataException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.ReplicaNotAvailableException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region ResourceNotFoundException - /// - /// - /// - public partial class ResourceNotFoundException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.ResourceNotFoundException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region RetriableException - /// - /// - /// - public partial class RetriableException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.RetriableException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region SaslAuthenticationException - /// - /// - /// - public partial class SaslAuthenticationException : Org.Apache.Kafka.Common.Errors.AuthenticationException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.SaslAuthenticationException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region SecurityDisabledException - /// - /// - /// - public partial class SecurityDisabledException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.SecurityDisabledException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region SerializationException - /// - /// - /// - public partial class SerializationException : Org.Apache.Kafka.Common.KafkaException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.SerializationException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region SnapshotNotFoundException - /// - /// - /// - public partial class SnapshotNotFoundException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.SnapshotNotFoundException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region SslAuthenticationException - /// - /// - /// - public partial class SslAuthenticationException : Org.Apache.Kafka.Common.Errors.AuthenticationException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.SslAuthenticationException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region StaleBrokerEpochException - /// - /// - /// - public partial class StaleBrokerEpochException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.StaleBrokerEpochException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region StaleMemberEpochException - /// - /// - /// - public partial class StaleMemberEpochException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.StaleMemberEpochException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region ThrottlingQuotaExceededException - /// - /// - /// - public partial class ThrottlingQuotaExceededException : Org.Apache.Kafka.Common.Errors.RetriableException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.ThrottlingQuotaExceededException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region TimeoutException - /// - /// - /// - public partial class TimeoutException : Org.Apache.Kafka.Common.Errors.RetriableException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.TimeoutException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region TopicAuthorizationException - /// - /// - /// - public partial class TopicAuthorizationException : Org.Apache.Kafka.Common.Errors.AuthorizationException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.TopicAuthorizationException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region TopicDeletionDisabledException - /// - /// - /// - public partial class TopicDeletionDisabledException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.TopicDeletionDisabledException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region TopicExistsException - /// - /// - /// - public partial class TopicExistsException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.TopicExistsException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region TransactionAbortedException - /// - /// - /// - public partial class TransactionAbortedException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.TransactionAbortedException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region TransactionalIdAuthorizationException - /// - /// - /// - public partial class TransactionalIdAuthorizationException : Org.Apache.Kafka.Common.Errors.AuthorizationException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.TransactionalIdAuthorizationException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region TransactionalIdNotFoundException - /// - /// - /// - public partial class TransactionalIdNotFoundException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.TransactionalIdNotFoundException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region TransactionCoordinatorFencedException - /// - /// - /// - public partial class TransactionCoordinatorFencedException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.TransactionCoordinatorFencedException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region UnacceptableCredentialException - /// - /// - /// - public partial class UnacceptableCredentialException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.UnacceptableCredentialException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region UnknownLeaderEpochException - /// - /// - /// - public partial class UnknownLeaderEpochException : Org.Apache.Kafka.Common.Errors.RetriableException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.UnknownLeaderEpochException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region UnknownMemberIdException - /// - /// - /// - public partial class UnknownMemberIdException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.UnknownMemberIdException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region UnknownProducerIdException - /// - /// - /// - public partial class UnknownProducerIdException : Org.Apache.Kafka.Common.Errors.OutOfOrderSequenceException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.UnknownProducerIdException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region UnknownServerException - /// - /// - /// - public partial class UnknownServerException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.UnknownServerException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region UnknownTopicIdException - /// - /// - /// - public partial class UnknownTopicIdException : Org.Apache.Kafka.Common.Errors.InvalidMetadataException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.UnknownTopicIdException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region UnknownTopicOrPartitionException - /// - /// - /// - public partial class UnknownTopicOrPartitionException : Org.Apache.Kafka.Common.Errors.InvalidMetadataException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.UnknownTopicOrPartitionException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region UnreleasedInstanceIdException - /// - /// - /// - public partial class UnreleasedInstanceIdException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.UnreleasedInstanceIdException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region UnstableOffsetCommitException - /// - /// - /// - public partial class UnstableOffsetCommitException : Org.Apache.Kafka.Common.Errors.RetriableException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.UnstableOffsetCommitException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region UnsupportedAssignorException - /// - /// - /// - public partial class UnsupportedAssignorException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.UnsupportedAssignorException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region UnsupportedByAuthenticationException - /// - /// - /// - public partial class UnsupportedByAuthenticationException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.UnsupportedByAuthenticationException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region UnsupportedCompressionTypeException - /// - /// - /// - public partial class UnsupportedCompressionTypeException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.UnsupportedCompressionTypeException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region UnsupportedForMessageFormatException - /// - /// - /// - public partial class UnsupportedForMessageFormatException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.UnsupportedForMessageFormatException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region UnsupportedSaslMechanismException - /// - /// - /// - public partial class UnsupportedSaslMechanismException : Org.Apache.Kafka.Common.Errors.AuthenticationException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.UnsupportedSaslMechanismException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region UnsupportedVersionException - /// - /// - /// - public partial class UnsupportedVersionException : Org.Apache.Kafka.Common.Errors.ApiException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.UnsupportedVersionException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region WakeupException - /// - /// - /// - public partial class WakeupException : Org.Apache.Kafka.Common.KafkaException - { - const string _bridgeClassName = "org.apache.kafka.common.errors.WakeupException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - - -} \ No newline at end of file diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ApiException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ApiException.cs index 338caddb8..932dac77f 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ApiException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ApiException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region ApiException + #region ApiException declaration + /// + /// + /// + public partial class ApiException : Org.Apache.Kafka.Common.KafkaException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.ApiException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region ApiException implementation public partial class ApiException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/AuthenticationException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/AuthenticationException.cs index 695e89f0c..8043b3181 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/AuthenticationException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/AuthenticationException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region AuthenticationException + #region AuthenticationException declaration + /// + /// + /// + public partial class AuthenticationException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.AuthenticationException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region AuthenticationException implementation public partial class AuthenticationException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/AuthorizationException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/AuthorizationException.cs index b654c7035..82a024ce9 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/AuthorizationException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/AuthorizationException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region AuthorizationException + #region AuthorizationException declaration + /// + /// + /// + public partial class AuthorizationException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.AuthorizationException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region AuthorizationException implementation public partial class AuthorizationException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/AuthorizerNotReadyException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/AuthorizerNotReadyException.cs index 0612895aa..fe8bdb2b0 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/AuthorizerNotReadyException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/AuthorizerNotReadyException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region AuthorizerNotReadyException + #region AuthorizerNotReadyException declaration + /// + /// + /// + public partial class AuthorizerNotReadyException : Org.Apache.Kafka.Common.Errors.RetriableException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.AuthorizerNotReadyException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region AuthorizerNotReadyException implementation public partial class AuthorizerNotReadyException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/BrokerIdNotRegisteredException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/BrokerIdNotRegisteredException.cs index b01acf044..f433ccb0d 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/BrokerIdNotRegisteredException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/BrokerIdNotRegisteredException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region BrokerIdNotRegisteredException + #region BrokerIdNotRegisteredException declaration + /// + /// + /// + public partial class BrokerIdNotRegisteredException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.BrokerIdNotRegisteredException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region BrokerIdNotRegisteredException implementation public partial class BrokerIdNotRegisteredException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/BrokerNotAvailableException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/BrokerNotAvailableException.cs index 4c3288dc5..d165d5545 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/BrokerNotAvailableException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/BrokerNotAvailableException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region BrokerNotAvailableException + #region BrokerNotAvailableException declaration + /// + /// + /// + public partial class BrokerNotAvailableException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.BrokerNotAvailableException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region BrokerNotAvailableException implementation public partial class BrokerNotAvailableException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ClusterAuthorizationException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ClusterAuthorizationException.cs index 2459ffaa1..ada7c5e90 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ClusterAuthorizationException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ClusterAuthorizationException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region ClusterAuthorizationException + #region ClusterAuthorizationException declaration + /// + /// + /// + public partial class ClusterAuthorizationException : Org.Apache.Kafka.Common.Errors.AuthorizationException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.ClusterAuthorizationException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region ClusterAuthorizationException implementation public partial class ClusterAuthorizationException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ConcurrentTransactionsException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ConcurrentTransactionsException.cs index 9413ac5b2..dc3d1db24 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ConcurrentTransactionsException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ConcurrentTransactionsException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region ConcurrentTransactionsException + #region ConcurrentTransactionsException declaration + /// + /// + /// + public partial class ConcurrentTransactionsException : Org.Apache.Kafka.Common.Errors.RetriableException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.ConcurrentTransactionsException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region ConcurrentTransactionsException implementation public partial class ConcurrentTransactionsException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ControllerMovedException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ControllerMovedException.cs index a4c2a27d6..fbb1e6cbb 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ControllerMovedException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ControllerMovedException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region ControllerMovedException + #region ControllerMovedException declaration + /// + /// + /// + public partial class ControllerMovedException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.ControllerMovedException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region ControllerMovedException implementation public partial class ControllerMovedException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/CoordinatorLoadInProgressException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/CoordinatorLoadInProgressException.cs index 708d44c4f..ec712e862 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/CoordinatorLoadInProgressException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/CoordinatorLoadInProgressException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region CoordinatorLoadInProgressException + #region CoordinatorLoadInProgressException declaration + /// + /// + /// + public partial class CoordinatorLoadInProgressException : Org.Apache.Kafka.Common.Errors.RetriableException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.CoordinatorLoadInProgressException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region CoordinatorLoadInProgressException implementation public partial class CoordinatorLoadInProgressException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/CoordinatorNotAvailableException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/CoordinatorNotAvailableException.cs index 8f51e4dae..eaa6619d7 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/CoordinatorNotAvailableException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/CoordinatorNotAvailableException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region CoordinatorNotAvailableException + #region CoordinatorNotAvailableException declaration + /// + /// + /// + public partial class CoordinatorNotAvailableException : Org.Apache.Kafka.Common.Errors.RetriableException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.CoordinatorNotAvailableException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region CoordinatorNotAvailableException implementation public partial class CoordinatorNotAvailableException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/CorruptRecordException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/CorruptRecordException.cs index 9399f3c53..28fefa40b 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/CorruptRecordException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/CorruptRecordException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region CorruptRecordException + #region CorruptRecordException declaration + /// + /// + /// + public partial class CorruptRecordException : Org.Apache.Kafka.Common.Errors.RetriableException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.CorruptRecordException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region CorruptRecordException implementation public partial class CorruptRecordException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DelegationTokenAuthorizationException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DelegationTokenAuthorizationException.cs index d33eef7ac..2dd064f36 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DelegationTokenAuthorizationException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DelegationTokenAuthorizationException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region DelegationTokenAuthorizationException + #region DelegationTokenAuthorizationException declaration + /// + /// + /// + public partial class DelegationTokenAuthorizationException : Org.Apache.Kafka.Common.Errors.AuthorizationException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.DelegationTokenAuthorizationException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region DelegationTokenAuthorizationException implementation public partial class DelegationTokenAuthorizationException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DelegationTokenDisabledException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DelegationTokenDisabledException.cs index 52752c378..2aa6c8ed1 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DelegationTokenDisabledException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DelegationTokenDisabledException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region DelegationTokenDisabledException + #region DelegationTokenDisabledException declaration + /// + /// + /// + public partial class DelegationTokenDisabledException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.DelegationTokenDisabledException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region DelegationTokenDisabledException implementation public partial class DelegationTokenDisabledException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DelegationTokenExpiredException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DelegationTokenExpiredException.cs index 4a6c5c753..53bcd369f 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DelegationTokenExpiredException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DelegationTokenExpiredException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region DelegationTokenExpiredException + #region DelegationTokenExpiredException declaration + /// + /// + /// + public partial class DelegationTokenExpiredException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.DelegationTokenExpiredException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region DelegationTokenExpiredException implementation public partial class DelegationTokenExpiredException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DelegationTokenNotFoundException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DelegationTokenNotFoundException.cs index 48f4cb1a0..ecf9161aa 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DelegationTokenNotFoundException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DelegationTokenNotFoundException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region DelegationTokenNotFoundException + #region DelegationTokenNotFoundException declaration + /// + /// + /// + public partial class DelegationTokenNotFoundException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.DelegationTokenNotFoundException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region DelegationTokenNotFoundException implementation public partial class DelegationTokenNotFoundException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DelegationTokenOwnerMismatchException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DelegationTokenOwnerMismatchException.cs index a1368043e..3b7f23fb2 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DelegationTokenOwnerMismatchException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DelegationTokenOwnerMismatchException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region DelegationTokenOwnerMismatchException + #region DelegationTokenOwnerMismatchException declaration + /// + /// + /// + public partial class DelegationTokenOwnerMismatchException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.DelegationTokenOwnerMismatchException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region DelegationTokenOwnerMismatchException implementation public partial class DelegationTokenOwnerMismatchException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DisconnectException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DisconnectException.cs index bdc20d13c..d451813cc 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DisconnectException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DisconnectException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region DisconnectException + #region DisconnectException declaration + /// + /// + /// + public partial class DisconnectException : Org.Apache.Kafka.Common.Errors.RetriableException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.DisconnectException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region DisconnectException implementation public partial class DisconnectException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DuplicateBrokerRegistrationException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DuplicateBrokerRegistrationException.cs index c0f7158d5..1d6b1b837 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DuplicateBrokerRegistrationException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DuplicateBrokerRegistrationException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region DuplicateBrokerRegistrationException + #region DuplicateBrokerRegistrationException declaration + /// + /// + /// + public partial class DuplicateBrokerRegistrationException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.DuplicateBrokerRegistrationException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region DuplicateBrokerRegistrationException implementation public partial class DuplicateBrokerRegistrationException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DuplicateResourceException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DuplicateResourceException.cs index d466af878..de8a9c722 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DuplicateResourceException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DuplicateResourceException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region DuplicateResourceException + #region DuplicateResourceException declaration + /// + /// + /// + public partial class DuplicateResourceException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.DuplicateResourceException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region DuplicateResourceException implementation public partial class DuplicateResourceException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DuplicateSequenceException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DuplicateSequenceException.cs index 365e5ae01..c8a58b37f 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DuplicateSequenceException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/DuplicateSequenceException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region DuplicateSequenceException + #region DuplicateSequenceException declaration + /// + /// + /// + public partial class DuplicateSequenceException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.DuplicateSequenceException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region DuplicateSequenceException implementation public partial class DuplicateSequenceException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ElectionNotNeededException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ElectionNotNeededException.cs index 7bf32bf3f..7fee74062 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ElectionNotNeededException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ElectionNotNeededException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region ElectionNotNeededException + #region ElectionNotNeededException declaration + /// + /// + /// + public partial class ElectionNotNeededException : Org.Apache.Kafka.Common.Errors.InvalidMetadataException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.ElectionNotNeededException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region ElectionNotNeededException implementation public partial class ElectionNotNeededException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/EligibleLeadersNotAvailableException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/EligibleLeadersNotAvailableException.cs index 9e1b4c5c7..eae3a47c6 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/EligibleLeadersNotAvailableException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/EligibleLeadersNotAvailableException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region EligibleLeadersNotAvailableException + #region EligibleLeadersNotAvailableException declaration + /// + /// + /// + public partial class EligibleLeadersNotAvailableException : Org.Apache.Kafka.Common.Errors.InvalidMetadataException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.EligibleLeadersNotAvailableException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region EligibleLeadersNotAvailableException implementation public partial class EligibleLeadersNotAvailableException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/FeatureUpdateFailedException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/FeatureUpdateFailedException.cs index 509ad76f7..70af5dded 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/FeatureUpdateFailedException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/FeatureUpdateFailedException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region FeatureUpdateFailedException + #region FeatureUpdateFailedException declaration + /// + /// + /// + public partial class FeatureUpdateFailedException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.FeatureUpdateFailedException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region FeatureUpdateFailedException implementation public partial class FeatureUpdateFailedException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/FencedInstanceIdException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/FencedInstanceIdException.cs index e0f502a8b..6117cc4d5 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/FencedInstanceIdException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/FencedInstanceIdException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region FencedInstanceIdException + #region FencedInstanceIdException declaration + /// + /// + /// + public partial class FencedInstanceIdException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.FencedInstanceIdException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region FencedInstanceIdException implementation public partial class FencedInstanceIdException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/FencedLeaderEpochException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/FencedLeaderEpochException.cs index 65cae3b55..49a4b17b9 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/FencedLeaderEpochException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/FencedLeaderEpochException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region FencedLeaderEpochException + #region FencedLeaderEpochException declaration + /// + /// + /// + public partial class FencedLeaderEpochException : Org.Apache.Kafka.Common.Errors.InvalidMetadataException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.FencedLeaderEpochException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region FencedLeaderEpochException implementation public partial class FencedLeaderEpochException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/FencedMemberEpochException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/FencedMemberEpochException.cs index 09a29fe13..39e385802 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/FencedMemberEpochException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/FencedMemberEpochException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region FencedMemberEpochException + #region FencedMemberEpochException declaration + /// + /// + /// + public partial class FencedMemberEpochException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.FencedMemberEpochException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region FencedMemberEpochException implementation public partial class FencedMemberEpochException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/FetchSessionIdNotFoundException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/FetchSessionIdNotFoundException.cs index eb1941b72..2454f3ee7 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/FetchSessionIdNotFoundException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/FetchSessionIdNotFoundException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region FetchSessionIdNotFoundException + #region FetchSessionIdNotFoundException declaration + /// + /// + /// + public partial class FetchSessionIdNotFoundException : Org.Apache.Kafka.Common.Errors.RetriableException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.FetchSessionIdNotFoundException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region FetchSessionIdNotFoundException implementation public partial class FetchSessionIdNotFoundException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/FetchSessionTopicIdException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/FetchSessionTopicIdException.cs index c346e61e5..ec20d6295 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/FetchSessionTopicIdException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/FetchSessionTopicIdException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region FetchSessionTopicIdException + #region FetchSessionTopicIdException declaration + /// + /// + /// + public partial class FetchSessionTopicIdException : Org.Apache.Kafka.Common.Errors.RetriableException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.FetchSessionTopicIdException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region FetchSessionTopicIdException implementation public partial class FetchSessionTopicIdException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/GroupAuthorizationException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/GroupAuthorizationException.cs index 6bb0af594..a75e07a40 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/GroupAuthorizationException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/GroupAuthorizationException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region GroupAuthorizationException + #region GroupAuthorizationException declaration + /// + /// + /// + public partial class GroupAuthorizationException : Org.Apache.Kafka.Common.Errors.AuthorizationException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.GroupAuthorizationException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region GroupAuthorizationException implementation public partial class GroupAuthorizationException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/GroupIdNotFoundException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/GroupIdNotFoundException.cs index b494ec238..f84403111 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/GroupIdNotFoundException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/GroupIdNotFoundException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region GroupIdNotFoundException + #region GroupIdNotFoundException declaration + /// + /// + /// + public partial class GroupIdNotFoundException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.GroupIdNotFoundException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region GroupIdNotFoundException implementation public partial class GroupIdNotFoundException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/GroupMaxSizeReachedException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/GroupMaxSizeReachedException.cs index 89732f6d2..db1972ec8 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/GroupMaxSizeReachedException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/GroupMaxSizeReachedException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region GroupMaxSizeReachedException + #region GroupMaxSizeReachedException declaration + /// + /// + /// + public partial class GroupMaxSizeReachedException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.GroupMaxSizeReachedException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region GroupMaxSizeReachedException implementation public partial class GroupMaxSizeReachedException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/GroupNotEmptyException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/GroupNotEmptyException.cs index 88c880907..8614dc48c 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/GroupNotEmptyException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/GroupNotEmptyException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region GroupNotEmptyException + #region GroupNotEmptyException declaration + /// + /// + /// + public partial class GroupNotEmptyException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.GroupNotEmptyException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region GroupNotEmptyException implementation public partial class GroupNotEmptyException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/GroupSubscribedToTopicException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/GroupSubscribedToTopicException.cs index 415be710e..6067c91d9 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/GroupSubscribedToTopicException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/GroupSubscribedToTopicException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region GroupSubscribedToTopicException + #region GroupSubscribedToTopicException declaration + /// + /// + /// + public partial class GroupSubscribedToTopicException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.GroupSubscribedToTopicException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region GroupSubscribedToTopicException implementation public partial class GroupSubscribedToTopicException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/IllegalGenerationException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/IllegalGenerationException.cs index 373c83556..5654f0ce3 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/IllegalGenerationException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/IllegalGenerationException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region IllegalGenerationException + #region IllegalGenerationException declaration + /// + /// + /// + public partial class IllegalGenerationException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.IllegalGenerationException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region IllegalGenerationException implementation public partial class IllegalGenerationException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/IllegalSaslStateException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/IllegalSaslStateException.cs index f891a7d52..1f35d2411 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/IllegalSaslStateException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/IllegalSaslStateException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region IllegalSaslStateException + #region IllegalSaslStateException declaration + /// + /// + /// + public partial class IllegalSaslStateException : Org.Apache.Kafka.Common.Errors.AuthenticationException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.IllegalSaslStateException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region IllegalSaslStateException implementation public partial class IllegalSaslStateException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InconsistentClusterIdException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InconsistentClusterIdException.cs index d3282368c..bdc79caf2 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InconsistentClusterIdException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InconsistentClusterIdException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region InconsistentClusterIdException + #region InconsistentClusterIdException declaration + /// + /// + /// + public partial class InconsistentClusterIdException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.InconsistentClusterIdException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region InconsistentClusterIdException implementation public partial class InconsistentClusterIdException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InconsistentGroupProtocolException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InconsistentGroupProtocolException.cs index fa7b5739f..70218d74c 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InconsistentGroupProtocolException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InconsistentGroupProtocolException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region InconsistentGroupProtocolException + #region InconsistentGroupProtocolException declaration + /// + /// + /// + public partial class InconsistentGroupProtocolException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.InconsistentGroupProtocolException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region InconsistentGroupProtocolException implementation public partial class InconsistentGroupProtocolException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InconsistentTopicIdException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InconsistentTopicIdException.cs index 3232a413c..2674d4c00 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InconsistentTopicIdException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InconsistentTopicIdException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region InconsistentTopicIdException + #region InconsistentTopicIdException declaration + /// + /// + /// + public partial class InconsistentTopicIdException : Org.Apache.Kafka.Common.Errors.InvalidMetadataException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.InconsistentTopicIdException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region InconsistentTopicIdException implementation public partial class InconsistentTopicIdException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InconsistentVoterSetException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InconsistentVoterSetException.cs index 03b03c454..1c33d0276 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InconsistentVoterSetException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InconsistentVoterSetException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region InconsistentVoterSetException + #region InconsistentVoterSetException declaration + /// + /// + /// + public partial class InconsistentVoterSetException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.InconsistentVoterSetException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region InconsistentVoterSetException implementation public partial class InconsistentVoterSetException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/IneligibleReplicaException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/IneligibleReplicaException.cs index 6cdc9a424..ffd3e9e72 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/IneligibleReplicaException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/IneligibleReplicaException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region IneligibleReplicaException + #region IneligibleReplicaException declaration + /// + /// + /// + public partial class IneligibleReplicaException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.IneligibleReplicaException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region IneligibleReplicaException implementation public partial class IneligibleReplicaException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InterruptException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InterruptException.cs index 16a5a90b3..cb1ae63c2 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InterruptException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InterruptException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region InterruptException + #region InterruptException declaration + /// + /// + /// + public partial class InterruptException : Org.Apache.Kafka.Common.KafkaException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.InterruptException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region InterruptException implementation public partial class InterruptException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidCommitOffsetSizeException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidCommitOffsetSizeException.cs index 4af39e726..35ea0b3f5 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidCommitOffsetSizeException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidCommitOffsetSizeException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region InvalidCommitOffsetSizeException + #region InvalidCommitOffsetSizeException declaration + /// + /// + /// + public partial class InvalidCommitOffsetSizeException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidCommitOffsetSizeException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region InvalidCommitOffsetSizeException implementation public partial class InvalidCommitOffsetSizeException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidConfigurationException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidConfigurationException.cs index 38c615f41..5dfd83441 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidConfigurationException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidConfigurationException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region InvalidConfigurationException + #region InvalidConfigurationException declaration + /// + /// + /// + public partial class InvalidConfigurationException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidConfigurationException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region InvalidConfigurationException implementation public partial class InvalidConfigurationException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidFetchSessionEpochException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidFetchSessionEpochException.cs index 2b6259c1d..33ee396ed 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidFetchSessionEpochException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidFetchSessionEpochException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region InvalidFetchSessionEpochException + #region InvalidFetchSessionEpochException declaration + /// + /// + /// + public partial class InvalidFetchSessionEpochException : Org.Apache.Kafka.Common.Errors.RetriableException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidFetchSessionEpochException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region InvalidFetchSessionEpochException implementation public partial class InvalidFetchSessionEpochException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidFetchSizeException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidFetchSizeException.cs index 110e4ff99..79e71c4f1 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidFetchSizeException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidFetchSizeException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region InvalidFetchSizeException + #region InvalidFetchSizeException declaration + /// + /// + /// + public partial class InvalidFetchSizeException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidFetchSizeException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region InvalidFetchSizeException implementation public partial class InvalidFetchSizeException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidGroupIdException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidGroupIdException.cs index b8c337b22..16dfa089a 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidGroupIdException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidGroupIdException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region InvalidGroupIdException + #region InvalidGroupIdException declaration + /// + /// + /// + public partial class InvalidGroupIdException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidGroupIdException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region InvalidGroupIdException implementation public partial class InvalidGroupIdException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidMetadataException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidMetadataException.cs index dd0f32c49..86a53a9c8 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidMetadataException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidMetadataException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region InvalidMetadataException + #region InvalidMetadataException declaration + /// + /// + /// + public partial class InvalidMetadataException : Org.Apache.Kafka.Common.Errors.RetriableException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidMetadataException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region InvalidMetadataException implementation public partial class InvalidMetadataException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidOffsetException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidOffsetException.cs index 0355de5f7..e4be5d103 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidOffsetException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidOffsetException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region InvalidOffsetException + #region InvalidOffsetException declaration + /// + /// + /// + public partial class InvalidOffsetException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidOffsetException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region InvalidOffsetException implementation public partial class InvalidOffsetException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidPartitionsException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidPartitionsException.cs index a2cc501c1..235f8f662 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidPartitionsException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidPartitionsException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region InvalidPartitionsException + #region InvalidPartitionsException declaration + /// + /// + /// + public partial class InvalidPartitionsException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidPartitionsException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region InvalidPartitionsException implementation public partial class InvalidPartitionsException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidPidMappingException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidPidMappingException.cs index f5a258ce1..77a741616 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidPidMappingException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidPidMappingException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region InvalidPidMappingException + #region InvalidPidMappingException declaration + /// + /// + /// + public partial class InvalidPidMappingException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidPidMappingException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region InvalidPidMappingException implementation public partial class InvalidPidMappingException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidPrincipalTypeException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidPrincipalTypeException.cs index d65654a7e..93186aef5 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidPrincipalTypeException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidPrincipalTypeException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region InvalidPrincipalTypeException + #region InvalidPrincipalTypeException declaration + /// + /// + /// + public partial class InvalidPrincipalTypeException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidPrincipalTypeException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region InvalidPrincipalTypeException implementation public partial class InvalidPrincipalTypeException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidProducerEpochException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidProducerEpochException.cs index 824b02891..1c2aa9a6a 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidProducerEpochException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidProducerEpochException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region InvalidProducerEpochException + #region InvalidProducerEpochException declaration + /// + /// + /// + public partial class InvalidProducerEpochException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidProducerEpochException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region InvalidProducerEpochException implementation public partial class InvalidProducerEpochException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidReplicaAssignmentException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidReplicaAssignmentException.cs index 3383cd30e..6e596527d 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidReplicaAssignmentException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidReplicaAssignmentException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region InvalidReplicaAssignmentException + #region InvalidReplicaAssignmentException declaration + /// + /// + /// + public partial class InvalidReplicaAssignmentException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidReplicaAssignmentException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region InvalidReplicaAssignmentException implementation public partial class InvalidReplicaAssignmentException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidReplicationFactorException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidReplicationFactorException.cs index 44463265a..bbef2a49b 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidReplicationFactorException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidReplicationFactorException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region InvalidReplicationFactorException + #region InvalidReplicationFactorException declaration + /// + /// + /// + public partial class InvalidReplicationFactorException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidReplicationFactorException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region InvalidReplicationFactorException implementation public partial class InvalidReplicationFactorException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidRequestException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidRequestException.cs index c3734ce82..60c33f7df 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidRequestException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidRequestException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region InvalidRequestException + #region InvalidRequestException declaration + /// + /// + /// + public partial class InvalidRequestException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidRequestException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region InvalidRequestException implementation public partial class InvalidRequestException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidRequiredAcksException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidRequiredAcksException.cs index 80b4b92f0..b708fcd4a 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidRequiredAcksException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidRequiredAcksException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region InvalidRequiredAcksException + #region InvalidRequiredAcksException declaration + /// + /// + /// + public partial class InvalidRequiredAcksException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidRequiredAcksException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region InvalidRequiredAcksException implementation public partial class InvalidRequiredAcksException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidSessionTimeoutException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidSessionTimeoutException.cs index b0ef40f7c..c9e1c05d3 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidSessionTimeoutException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidSessionTimeoutException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region InvalidSessionTimeoutException + #region InvalidSessionTimeoutException declaration + /// + /// + /// + public partial class InvalidSessionTimeoutException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidSessionTimeoutException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region InvalidSessionTimeoutException implementation public partial class InvalidSessionTimeoutException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidTimestampException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidTimestampException.cs index 060216a3a..d7341ae80 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidTimestampException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidTimestampException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region InvalidTimestampException + #region InvalidTimestampException declaration + /// + /// + /// + public partial class InvalidTimestampException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidTimestampException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region InvalidTimestampException implementation public partial class InvalidTimestampException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidTopicException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidTopicException.cs index 3bda631d9..ff01b3f1d 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidTopicException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidTopicException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region InvalidTopicException + #region InvalidTopicException declaration + /// + /// + /// + public partial class InvalidTopicException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidTopicException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region InvalidTopicException implementation public partial class InvalidTopicException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidTxnStateException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidTxnStateException.cs index 448d9064c..e335db073 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidTxnStateException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidTxnStateException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region InvalidTxnStateException + #region InvalidTxnStateException declaration + /// + /// + /// + public partial class InvalidTxnStateException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidTxnStateException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region InvalidTxnStateException implementation public partial class InvalidTxnStateException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidTxnTimeoutException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidTxnTimeoutException.cs index f6f55a79e..46b149704 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidTxnTimeoutException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidTxnTimeoutException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region InvalidTxnTimeoutException + #region InvalidTxnTimeoutException declaration + /// + /// + /// + public partial class InvalidTxnTimeoutException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidTxnTimeoutException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region InvalidTxnTimeoutException implementation public partial class InvalidTxnTimeoutException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidUpdateVersionException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidUpdateVersionException.cs index 469f7aab8..798710603 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidUpdateVersionException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/InvalidUpdateVersionException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region InvalidUpdateVersionException + #region InvalidUpdateVersionException declaration + /// + /// + /// + public partial class InvalidUpdateVersionException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.InvalidUpdateVersionException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region InvalidUpdateVersionException implementation public partial class InvalidUpdateVersionException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/KafkaStorageException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/KafkaStorageException.cs index cf500f74f..57e0a399b 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/KafkaStorageException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/KafkaStorageException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region KafkaStorageException + #region KafkaStorageException declaration + /// + /// + /// + public partial class KafkaStorageException : Org.Apache.Kafka.Common.Errors.InvalidMetadataException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.KafkaStorageException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region KafkaStorageException implementation public partial class KafkaStorageException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/LeaderNotAvailableException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/LeaderNotAvailableException.cs index db9aca4c2..b9d904e37 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/LeaderNotAvailableException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/LeaderNotAvailableException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region LeaderNotAvailableException + #region LeaderNotAvailableException declaration + /// + /// + /// + public partial class LeaderNotAvailableException : Org.Apache.Kafka.Common.Errors.InvalidMetadataException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.LeaderNotAvailableException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region LeaderNotAvailableException implementation public partial class LeaderNotAvailableException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ListenerNotFoundException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ListenerNotFoundException.cs index 95d05fbe6..e8af0100e 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ListenerNotFoundException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ListenerNotFoundException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region ListenerNotFoundException + #region ListenerNotFoundException declaration + /// + /// + /// + public partial class ListenerNotFoundException : Org.Apache.Kafka.Common.Errors.InvalidMetadataException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.ListenerNotFoundException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region ListenerNotFoundException implementation public partial class ListenerNotFoundException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/LogDirNotFoundException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/LogDirNotFoundException.cs index 5e949234a..2c1c331ad 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/LogDirNotFoundException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/LogDirNotFoundException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region LogDirNotFoundException + #region LogDirNotFoundException declaration + /// + /// + /// + public partial class LogDirNotFoundException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.LogDirNotFoundException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region LogDirNotFoundException implementation public partial class LogDirNotFoundException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/MemberIdRequiredException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/MemberIdRequiredException.cs index de4c0e8b7..5d91dbbbd 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/MemberIdRequiredException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/MemberIdRequiredException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region MemberIdRequiredException + #region MemberIdRequiredException declaration + /// + /// + /// + public partial class MemberIdRequiredException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.MemberIdRequiredException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region MemberIdRequiredException implementation public partial class MemberIdRequiredException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NetworkException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NetworkException.cs index 2142ab771..c94b96b55 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NetworkException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NetworkException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region NetworkException + #region NetworkException declaration + /// + /// + /// + public partial class NetworkException : Org.Apache.Kafka.Common.Errors.InvalidMetadataException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.NetworkException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region NetworkException implementation public partial class NetworkException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NewLeaderElectedException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NewLeaderElectedException.cs index 9ceda5374..37b847a17 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NewLeaderElectedException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NewLeaderElectedException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region NewLeaderElectedException + #region NewLeaderElectedException declaration + /// + /// + /// + public partial class NewLeaderElectedException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.NewLeaderElectedException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region NewLeaderElectedException implementation public partial class NewLeaderElectedException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NoReassignmentInProgressException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NoReassignmentInProgressException.cs index 18032827e..4d222a61c 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NoReassignmentInProgressException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NoReassignmentInProgressException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region NoReassignmentInProgressException + #region NoReassignmentInProgressException declaration + /// + /// + /// + public partial class NoReassignmentInProgressException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.NoReassignmentInProgressException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region NoReassignmentInProgressException implementation public partial class NoReassignmentInProgressException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NotControllerException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NotControllerException.cs index 9c47fb745..8c4338d99 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NotControllerException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NotControllerException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region NotControllerException + #region NotControllerException declaration + /// + /// + /// + public partial class NotControllerException : Org.Apache.Kafka.Common.Errors.RetriableException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.NotControllerException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region NotControllerException implementation public partial class NotControllerException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NotCoordinatorException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NotCoordinatorException.cs index 7bb78c0ff..5128e4aef 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NotCoordinatorException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NotCoordinatorException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region NotCoordinatorException + #region NotCoordinatorException declaration + /// + /// + /// + public partial class NotCoordinatorException : Org.Apache.Kafka.Common.Errors.RetriableException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.NotCoordinatorException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region NotCoordinatorException implementation public partial class NotCoordinatorException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NotEnoughReplicasAfterAppendException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NotEnoughReplicasAfterAppendException.cs index fd3e7b824..4dc153beb 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NotEnoughReplicasAfterAppendException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NotEnoughReplicasAfterAppendException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region NotEnoughReplicasAfterAppendException + #region NotEnoughReplicasAfterAppendException declaration + /// + /// + /// + public partial class NotEnoughReplicasAfterAppendException : Org.Apache.Kafka.Common.Errors.RetriableException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.NotEnoughReplicasAfterAppendException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region NotEnoughReplicasAfterAppendException implementation public partial class NotEnoughReplicasAfterAppendException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NotEnoughReplicasException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NotEnoughReplicasException.cs index 2e6a50207..e48a3cf06 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NotEnoughReplicasException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NotEnoughReplicasException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region NotEnoughReplicasException + #region NotEnoughReplicasException declaration + /// + /// + /// + public partial class NotEnoughReplicasException : Org.Apache.Kafka.Common.Errors.RetriableException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.NotEnoughReplicasException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region NotEnoughReplicasException implementation public partial class NotEnoughReplicasException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NotLeaderOrFollowerException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NotLeaderOrFollowerException.cs index b7e379c97..1df1a275c 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NotLeaderOrFollowerException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/NotLeaderOrFollowerException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region NotLeaderOrFollowerException + #region NotLeaderOrFollowerException declaration + /// + /// + /// + public partial class NotLeaderOrFollowerException : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.errors.NotLeaderOrFollowerException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region NotLeaderOrFollowerException implementation public partial class NotLeaderOrFollowerException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/OffsetMetadataTooLarge.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/OffsetMetadataTooLarge.cs index d0118b00d..d17c1e9f9 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/OffsetMetadataTooLarge.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/OffsetMetadataTooLarge.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region OffsetMetadataTooLarge + #region OffsetMetadataTooLarge declaration + /// + /// + /// + public partial class OffsetMetadataTooLarge : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.OffsetMetadataTooLarge"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region OffsetMetadataTooLarge implementation public partial class OffsetMetadataTooLarge { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/OffsetMovedToTieredStorageException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/OffsetMovedToTieredStorageException.cs index f78a900a2..910bf5dcb 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/OffsetMovedToTieredStorageException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/OffsetMovedToTieredStorageException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region OffsetMovedToTieredStorageException + #region OffsetMovedToTieredStorageException declaration + /// + /// + /// + public partial class OffsetMovedToTieredStorageException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.OffsetMovedToTieredStorageException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region OffsetMovedToTieredStorageException implementation public partial class OffsetMovedToTieredStorageException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/OffsetNotAvailableException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/OffsetNotAvailableException.cs index 474a5016a..1f6ecc632 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/OffsetNotAvailableException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/OffsetNotAvailableException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region OffsetNotAvailableException + #region OffsetNotAvailableException declaration + /// + /// + /// + public partial class OffsetNotAvailableException : Org.Apache.Kafka.Common.Errors.RetriableException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.OffsetNotAvailableException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region OffsetNotAvailableException implementation public partial class OffsetNotAvailableException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/OffsetOutOfRangeException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/OffsetOutOfRangeException.cs index 1994755af..6e04f3451 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/OffsetOutOfRangeException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/OffsetOutOfRangeException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region OffsetOutOfRangeException + #region OffsetOutOfRangeException declaration + /// + /// + /// + public partial class OffsetOutOfRangeException : Org.Apache.Kafka.Common.Errors.InvalidOffsetException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.OffsetOutOfRangeException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region OffsetOutOfRangeException implementation public partial class OffsetOutOfRangeException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/OperationNotAttemptedException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/OperationNotAttemptedException.cs index f3e2a2c53..645a13dbd 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/OperationNotAttemptedException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/OperationNotAttemptedException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region OperationNotAttemptedException + #region OperationNotAttemptedException declaration + /// + /// + /// + public partial class OperationNotAttemptedException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.OperationNotAttemptedException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region OperationNotAttemptedException implementation public partial class OperationNotAttemptedException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/OutOfOrderSequenceException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/OutOfOrderSequenceException.cs index c7e88ea52..f0a57bbab 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/OutOfOrderSequenceException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/OutOfOrderSequenceException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region OutOfOrderSequenceException + #region OutOfOrderSequenceException declaration + /// + /// + /// + public partial class OutOfOrderSequenceException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.OutOfOrderSequenceException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region OutOfOrderSequenceException implementation public partial class OutOfOrderSequenceException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/PolicyViolationException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/PolicyViolationException.cs index d19dfc635..1fa12030a 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/PolicyViolationException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/PolicyViolationException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region PolicyViolationException + #region PolicyViolationException declaration + /// + /// + /// + public partial class PolicyViolationException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.PolicyViolationException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region PolicyViolationException implementation public partial class PolicyViolationException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/PositionOutOfRangeException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/PositionOutOfRangeException.cs index dbbf44669..9a795d05d 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/PositionOutOfRangeException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/PositionOutOfRangeException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region PositionOutOfRangeException + #region PositionOutOfRangeException declaration + /// + /// + /// + public partial class PositionOutOfRangeException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.PositionOutOfRangeException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region PositionOutOfRangeException implementation public partial class PositionOutOfRangeException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/PreferredLeaderNotAvailableException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/PreferredLeaderNotAvailableException.cs index 00ab6af06..314e01771 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/PreferredLeaderNotAvailableException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/PreferredLeaderNotAvailableException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region PreferredLeaderNotAvailableException + #region PreferredLeaderNotAvailableException declaration + /// + /// + /// + public partial class PreferredLeaderNotAvailableException : Org.Apache.Kafka.Common.Errors.InvalidMetadataException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.PreferredLeaderNotAvailableException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region PreferredLeaderNotAvailableException implementation public partial class PreferredLeaderNotAvailableException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/PrincipalDeserializationException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/PrincipalDeserializationException.cs index 5afc01373..bb480cf5f 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/PrincipalDeserializationException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/PrincipalDeserializationException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region PrincipalDeserializationException + #region PrincipalDeserializationException declaration + /// + /// + /// + public partial class PrincipalDeserializationException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.PrincipalDeserializationException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region PrincipalDeserializationException implementation public partial class PrincipalDeserializationException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ProducerFencedException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ProducerFencedException.cs index 384e59b6f..63a0537f7 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ProducerFencedException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ProducerFencedException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region ProducerFencedException + #region ProducerFencedException declaration + /// + /// + /// + public partial class ProducerFencedException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.ProducerFencedException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region ProducerFencedException implementation public partial class ProducerFencedException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ReassignmentInProgressException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ReassignmentInProgressException.cs index 726a443fe..1ae19ad8e 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ReassignmentInProgressException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ReassignmentInProgressException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region ReassignmentInProgressException + #region ReassignmentInProgressException declaration + /// + /// + /// + public partial class ReassignmentInProgressException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.ReassignmentInProgressException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region ReassignmentInProgressException implementation public partial class ReassignmentInProgressException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/RebalanceInProgressException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/RebalanceInProgressException.cs index 8c68cb60e..8749bac69 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/RebalanceInProgressException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/RebalanceInProgressException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region RebalanceInProgressException + #region RebalanceInProgressException declaration + /// + /// + /// + public partial class RebalanceInProgressException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.RebalanceInProgressException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region RebalanceInProgressException implementation public partial class RebalanceInProgressException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/RecordBatchTooLargeException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/RecordBatchTooLargeException.cs index 9c3def78f..57cc61c97 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/RecordBatchTooLargeException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/RecordBatchTooLargeException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region RecordBatchTooLargeException + #region RecordBatchTooLargeException declaration + /// + /// + /// + public partial class RecordBatchTooLargeException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.RecordBatchTooLargeException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region RecordBatchTooLargeException implementation public partial class RecordBatchTooLargeException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/RecordDeserializationException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/RecordDeserializationException.cs index 261890798..efab2a048 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/RecordDeserializationException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/RecordDeserializationException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region RecordDeserializationException + #region RecordDeserializationException declaration + /// + /// + /// + public partial class RecordDeserializationException : Org.Apache.Kafka.Common.Errors.SerializationException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.RecordDeserializationException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region RecordDeserializationException implementation public partial class RecordDeserializationException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/RecordTooLargeException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/RecordTooLargeException.cs index 13e9d737d..6c5e65998 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/RecordTooLargeException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/RecordTooLargeException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region RecordTooLargeException + #region RecordTooLargeException declaration + /// + /// + /// + public partial class RecordTooLargeException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.RecordTooLargeException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region RecordTooLargeException implementation public partial class RecordTooLargeException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ReplicaNotAvailableException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ReplicaNotAvailableException.cs index a6a37b85d..f4d0f636a 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ReplicaNotAvailableException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ReplicaNotAvailableException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region ReplicaNotAvailableException + #region ReplicaNotAvailableException declaration + /// + /// + /// + public partial class ReplicaNotAvailableException : Org.Apache.Kafka.Common.Errors.InvalidMetadataException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.ReplicaNotAvailableException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region ReplicaNotAvailableException implementation public partial class ReplicaNotAvailableException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ResourceNotFoundException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ResourceNotFoundException.cs index 699ac32a2..89167b2f7 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ResourceNotFoundException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ResourceNotFoundException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region ResourceNotFoundException + #region ResourceNotFoundException declaration + /// + /// + /// + public partial class ResourceNotFoundException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.ResourceNotFoundException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region ResourceNotFoundException implementation public partial class ResourceNotFoundException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/RetriableException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/RetriableException.cs index 2027f9282..7aa7e96ab 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/RetriableException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/RetriableException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region RetriableException + #region RetriableException declaration + /// + /// + /// + public partial class RetriableException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.RetriableException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region RetriableException implementation public partial class RetriableException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/SaslAuthenticationException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/SaslAuthenticationException.cs index ed0c4a9b7..52984465b 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/SaslAuthenticationException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/SaslAuthenticationException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region SaslAuthenticationException + #region SaslAuthenticationException declaration + /// + /// + /// + public partial class SaslAuthenticationException : Org.Apache.Kafka.Common.Errors.AuthenticationException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.SaslAuthenticationException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region SaslAuthenticationException implementation public partial class SaslAuthenticationException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/SecurityDisabledException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/SecurityDisabledException.cs index 1e19f3945..e68787b39 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/SecurityDisabledException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/SecurityDisabledException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region SecurityDisabledException + #region SecurityDisabledException declaration + /// + /// + /// + public partial class SecurityDisabledException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.SecurityDisabledException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region SecurityDisabledException implementation public partial class SecurityDisabledException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/SerializationException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/SerializationException.cs index 966513d3c..1183bade8 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/SerializationException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/SerializationException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region SerializationException + #region SerializationException declaration + /// + /// + /// + public partial class SerializationException : Org.Apache.Kafka.Common.KafkaException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.SerializationException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region SerializationException implementation public partial class SerializationException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/SnapshotNotFoundException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/SnapshotNotFoundException.cs index bf243ffc6..4b2d5a91c 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/SnapshotNotFoundException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/SnapshotNotFoundException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region SnapshotNotFoundException + #region SnapshotNotFoundException declaration + /// + /// + /// + public partial class SnapshotNotFoundException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.SnapshotNotFoundException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region SnapshotNotFoundException implementation public partial class SnapshotNotFoundException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/SslAuthenticationException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/SslAuthenticationException.cs index 0661e827a..711b33572 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/SslAuthenticationException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/SslAuthenticationException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region SslAuthenticationException + #region SslAuthenticationException declaration + /// + /// + /// + public partial class SslAuthenticationException : Org.Apache.Kafka.Common.Errors.AuthenticationException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.SslAuthenticationException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region SslAuthenticationException implementation public partial class SslAuthenticationException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/StaleBrokerEpochException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/StaleBrokerEpochException.cs index 807ad71fa..8740dc494 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/StaleBrokerEpochException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/StaleBrokerEpochException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region StaleBrokerEpochException + #region StaleBrokerEpochException declaration + /// + /// + /// + public partial class StaleBrokerEpochException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.StaleBrokerEpochException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region StaleBrokerEpochException implementation public partial class StaleBrokerEpochException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/StaleMemberEpochException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/StaleMemberEpochException.cs index 31ede1adc..01f05fe2e 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/StaleMemberEpochException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/StaleMemberEpochException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region StaleMemberEpochException + #region StaleMemberEpochException declaration + /// + /// + /// + public partial class StaleMemberEpochException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.StaleMemberEpochException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region StaleMemberEpochException implementation public partial class StaleMemberEpochException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ThrottlingQuotaExceededException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ThrottlingQuotaExceededException.cs index e0bec8652..3e5bb44bb 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ThrottlingQuotaExceededException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/ThrottlingQuotaExceededException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region ThrottlingQuotaExceededException + #region ThrottlingQuotaExceededException declaration + /// + /// + /// + public partial class ThrottlingQuotaExceededException : Org.Apache.Kafka.Common.Errors.RetriableException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.ThrottlingQuotaExceededException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region ThrottlingQuotaExceededException implementation public partial class ThrottlingQuotaExceededException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TimeoutException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TimeoutException.cs index 3146fa9a7..96f813d68 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TimeoutException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TimeoutException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region TimeoutException + #region TimeoutException declaration + /// + /// + /// + public partial class TimeoutException : Org.Apache.Kafka.Common.Errors.RetriableException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.TimeoutException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region TimeoutException implementation public partial class TimeoutException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TopicAuthorizationException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TopicAuthorizationException.cs index 3c38186f5..c0bd0064c 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TopicAuthorizationException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TopicAuthorizationException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region TopicAuthorizationException + #region TopicAuthorizationException declaration + /// + /// + /// + public partial class TopicAuthorizationException : Org.Apache.Kafka.Common.Errors.AuthorizationException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.TopicAuthorizationException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region TopicAuthorizationException implementation public partial class TopicAuthorizationException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TopicDeletionDisabledException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TopicDeletionDisabledException.cs index 423678ac7..cba7e81b0 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TopicDeletionDisabledException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TopicDeletionDisabledException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region TopicDeletionDisabledException + #region TopicDeletionDisabledException declaration + /// + /// + /// + public partial class TopicDeletionDisabledException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.TopicDeletionDisabledException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region TopicDeletionDisabledException implementation public partial class TopicDeletionDisabledException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TopicExistsException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TopicExistsException.cs index c69fd13e5..aa0578d89 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TopicExistsException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TopicExistsException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region TopicExistsException + #region TopicExistsException declaration + /// + /// + /// + public partial class TopicExistsException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.TopicExistsException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region TopicExistsException implementation public partial class TopicExistsException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TransactionAbortedException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TransactionAbortedException.cs index dd089b8e0..5ff6fa766 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TransactionAbortedException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TransactionAbortedException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region TransactionAbortedException + #region TransactionAbortedException declaration + /// + /// + /// + public partial class TransactionAbortedException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.TransactionAbortedException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region TransactionAbortedException implementation public partial class TransactionAbortedException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TransactionCoordinatorFencedException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TransactionCoordinatorFencedException.cs index e4056af82..b702fba40 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TransactionCoordinatorFencedException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TransactionCoordinatorFencedException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region TransactionCoordinatorFencedException + #region TransactionCoordinatorFencedException declaration + /// + /// + /// + public partial class TransactionCoordinatorFencedException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.TransactionCoordinatorFencedException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region TransactionCoordinatorFencedException implementation public partial class TransactionCoordinatorFencedException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TransactionalIdAuthorizationException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TransactionalIdAuthorizationException.cs index b2f140b32..690f66aa0 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TransactionalIdAuthorizationException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TransactionalIdAuthorizationException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region TransactionalIdAuthorizationException + #region TransactionalIdAuthorizationException declaration + /// + /// + /// + public partial class TransactionalIdAuthorizationException : Org.Apache.Kafka.Common.Errors.AuthorizationException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.TransactionalIdAuthorizationException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region TransactionalIdAuthorizationException implementation public partial class TransactionalIdAuthorizationException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TransactionalIdNotFoundException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TransactionalIdNotFoundException.cs index 6258809cf..112a42f7f 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TransactionalIdNotFoundException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/TransactionalIdNotFoundException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region TransactionalIdNotFoundException + #region TransactionalIdNotFoundException declaration + /// + /// + /// + public partial class TransactionalIdNotFoundException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.TransactionalIdNotFoundException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region TransactionalIdNotFoundException implementation public partial class TransactionalIdNotFoundException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnacceptableCredentialException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnacceptableCredentialException.cs index 85e7b6d2f..6e7ee46d3 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnacceptableCredentialException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnacceptableCredentialException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region UnacceptableCredentialException + #region UnacceptableCredentialException declaration + /// + /// + /// + public partial class UnacceptableCredentialException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.UnacceptableCredentialException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region UnacceptableCredentialException implementation public partial class UnacceptableCredentialException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnknownLeaderEpochException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnknownLeaderEpochException.cs index 1c18f07d0..6018d650b 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnknownLeaderEpochException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnknownLeaderEpochException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region UnknownLeaderEpochException + #region UnknownLeaderEpochException declaration + /// + /// + /// + public partial class UnknownLeaderEpochException : Org.Apache.Kafka.Common.Errors.RetriableException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.UnknownLeaderEpochException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region UnknownLeaderEpochException implementation public partial class UnknownLeaderEpochException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnknownMemberIdException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnknownMemberIdException.cs index b733fc6fb..738241aa2 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnknownMemberIdException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnknownMemberIdException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region UnknownMemberIdException + #region UnknownMemberIdException declaration + /// + /// + /// + public partial class UnknownMemberIdException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.UnknownMemberIdException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region UnknownMemberIdException implementation public partial class UnknownMemberIdException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnknownProducerIdException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnknownProducerIdException.cs index 1ce849fd3..04c946b82 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnknownProducerIdException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnknownProducerIdException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region UnknownProducerIdException + #region UnknownProducerIdException declaration + /// + /// + /// + public partial class UnknownProducerIdException : Org.Apache.Kafka.Common.Errors.OutOfOrderSequenceException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.UnknownProducerIdException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region UnknownProducerIdException implementation public partial class UnknownProducerIdException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnknownServerException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnknownServerException.cs index 5b00c3cfc..4e9178a61 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnknownServerException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnknownServerException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region UnknownServerException + #region UnknownServerException declaration + /// + /// + /// + public partial class UnknownServerException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.UnknownServerException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region UnknownServerException implementation public partial class UnknownServerException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnknownTopicIdException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnknownTopicIdException.cs index 7857d9345..11475f27e 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnknownTopicIdException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnknownTopicIdException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region UnknownTopicIdException + #region UnknownTopicIdException declaration + /// + /// + /// + public partial class UnknownTopicIdException : Org.Apache.Kafka.Common.Errors.InvalidMetadataException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.UnknownTopicIdException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region UnknownTopicIdException implementation public partial class UnknownTopicIdException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnknownTopicOrPartitionException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnknownTopicOrPartitionException.cs index 4ccc41b9a..ade7ee938 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnknownTopicOrPartitionException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnknownTopicOrPartitionException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region UnknownTopicOrPartitionException + #region UnknownTopicOrPartitionException declaration + /// + /// + /// + public partial class UnknownTopicOrPartitionException : Org.Apache.Kafka.Common.Errors.InvalidMetadataException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.UnknownTopicOrPartitionException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region UnknownTopicOrPartitionException implementation public partial class UnknownTopicOrPartitionException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnreleasedInstanceIdException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnreleasedInstanceIdException.cs index 6c867a525..d2c9744da 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnreleasedInstanceIdException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnreleasedInstanceIdException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region UnreleasedInstanceIdException + #region UnreleasedInstanceIdException declaration + /// + /// + /// + public partial class UnreleasedInstanceIdException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.UnreleasedInstanceIdException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region UnreleasedInstanceIdException implementation public partial class UnreleasedInstanceIdException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnstableOffsetCommitException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnstableOffsetCommitException.cs index 9a8d58ed3..a718439d5 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnstableOffsetCommitException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnstableOffsetCommitException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region UnstableOffsetCommitException + #region UnstableOffsetCommitException declaration + /// + /// + /// + public partial class UnstableOffsetCommitException : Org.Apache.Kafka.Common.Errors.RetriableException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.UnstableOffsetCommitException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region UnstableOffsetCommitException implementation public partial class UnstableOffsetCommitException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnsupportedAssignorException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnsupportedAssignorException.cs index bf62f6e2d..f2912af9b 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnsupportedAssignorException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnsupportedAssignorException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region UnsupportedAssignorException + #region UnsupportedAssignorException declaration + /// + /// + /// + public partial class UnsupportedAssignorException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.UnsupportedAssignorException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region UnsupportedAssignorException implementation public partial class UnsupportedAssignorException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnsupportedByAuthenticationException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnsupportedByAuthenticationException.cs index b74883ad9..f7d4f8f05 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnsupportedByAuthenticationException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnsupportedByAuthenticationException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region UnsupportedByAuthenticationException + #region UnsupportedByAuthenticationException declaration + /// + /// + /// + public partial class UnsupportedByAuthenticationException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.UnsupportedByAuthenticationException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region UnsupportedByAuthenticationException implementation public partial class UnsupportedByAuthenticationException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnsupportedCompressionTypeException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnsupportedCompressionTypeException.cs index 457b5812b..7e7bbf38d 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnsupportedCompressionTypeException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnsupportedCompressionTypeException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region UnsupportedCompressionTypeException + #region UnsupportedCompressionTypeException declaration + /// + /// + /// + public partial class UnsupportedCompressionTypeException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.UnsupportedCompressionTypeException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region UnsupportedCompressionTypeException implementation public partial class UnsupportedCompressionTypeException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnsupportedForMessageFormatException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnsupportedForMessageFormatException.cs index 6140bc670..7a945f696 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnsupportedForMessageFormatException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnsupportedForMessageFormatException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region UnsupportedForMessageFormatException + #region UnsupportedForMessageFormatException declaration + /// + /// + /// + public partial class UnsupportedForMessageFormatException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.UnsupportedForMessageFormatException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region UnsupportedForMessageFormatException implementation public partial class UnsupportedForMessageFormatException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnsupportedSaslMechanismException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnsupportedSaslMechanismException.cs index 400c5b58e..6e773631f 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnsupportedSaslMechanismException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnsupportedSaslMechanismException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region UnsupportedSaslMechanismException + #region UnsupportedSaslMechanismException declaration + /// + /// + /// + public partial class UnsupportedSaslMechanismException : Org.Apache.Kafka.Common.Errors.AuthenticationException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.UnsupportedSaslMechanismException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region UnsupportedSaslMechanismException implementation public partial class UnsupportedSaslMechanismException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnsupportedVersionException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnsupportedVersionException.cs index 5a38e0943..58227c73b 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnsupportedVersionException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/UnsupportedVersionException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region UnsupportedVersionException + #region UnsupportedVersionException declaration + /// + /// + /// + public partial class UnsupportedVersionException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.UnsupportedVersionException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region UnsupportedVersionException implementation public partial class UnsupportedVersionException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/WakeupException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/WakeupException.cs index e7293248b..e82b3254a 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/WakeupException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/WakeupException.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,24 @@ namespace Org.Apache.Kafka.Common.Errors { - #region WakeupException + #region WakeupException declaration + /// + /// + /// + public partial class WakeupException : Org.Apache.Kafka.Common.KafkaException + { + const string _bridgeClassName = "org.apache.kafka.common.errors.WakeupException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region WakeupException implementation public partial class WakeupException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Header/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Header/AllPackageClasses.cs deleted file mode 100644 index 13f84f7dc..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Header/AllPackageClasses.cs +++ /dev/null @@ -1,125 +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.Common.Header -{ - #region Header - /// - /// - /// - public partial class Header : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- { - const string _bridgeClassName = "org.apache.kafka.common.header.Header"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("Header 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 Header() { } - /// - /// 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("Header 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 Header(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 Headers - /// - /// - /// - public partial class Headers : Java.Lang.Iterable - { - const string _bridgeClassName = "org.apache.kafka.common.header.Headers"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("Headers 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 Headers() { } - /// - /// 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("Headers 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 Headers(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 - - - -} \ No newline at end of file diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Header/Header.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Header/Header.cs index 5567f71bd..4bf32fbb3 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Header/Header.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Header/Header.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.Common.Header { + #region Header declaration + /// + /// + /// + public partial class Header : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ { + const string _bridgeClassName = "org.apache.kafka.common.header.Header"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("Header 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 Header() { } + /// + /// 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("Header 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 Header(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 IHeader /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +90,7 @@ public partial interface IHeader } #endregion - #region Header + #region Header implementation public partial class Header : Org.Apache.Kafka.Common.Header.IHeader { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Header/Headers.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Header/Headers.cs index d93161449..e7500f033 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Header/Headers.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Header/Headers.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.Common.Header { + #region Headers declaration + /// + /// + /// + public partial class Headers : Java.Lang.Iterable + { + const string _bridgeClassName = "org.apache.kafka.common.header.Headers"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("Headers 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 Headers() { } + /// + /// 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("Headers 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 Headers(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 IHeaders /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +90,7 @@ public partial interface IHeaders } #endregion - #region Headers + #region Headers implementation public partial class Headers : Org.Apache.Kafka.Common.Header.IHeaders { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/InvalidRecordException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/InvalidRecordException.cs index 016c8b507..3f205592e 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/InvalidRecordException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/InvalidRecordException.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,24 @@ namespace Org.Apache.Kafka.Common { - #region InvalidRecordException + #region InvalidRecordException declaration + /// + /// + /// + public partial class InvalidRecordException : Org.Apache.Kafka.Common.Errors.ApiException + { + const string _bridgeClassName = "org.apache.kafka.common.InvalidRecordException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region InvalidRecordException implementation public partial class InvalidRecordException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/IsolationLevel.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/IsolationLevel.cs index 8fb83c589..2b0526210 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/IsolationLevel.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/IsolationLevel.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.Common { - #region IsolationLevel + #region IsolationLevel declaration + /// + /// + /// + public partial class IsolationLevel : Java.Lang.Enum + { + const string _bridgeClassName = "org.apache.kafka.common.IsolationLevel"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public IsolationLevel() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public IsolationLevel(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 IsolationLevel implementation public partial class IsolationLevel { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/KafkaException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/KafkaException.cs index 6562a668a..eec925427 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/KafkaException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/KafkaException.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,24 @@ namespace Org.Apache.Kafka.Common { - #region KafkaException + #region KafkaException declaration + /// + /// + /// + public partial class KafkaException : Java.Lang.RuntimeException + { + const string _bridgeClassName = "org.apache.kafka.common.KafkaException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region KafkaException implementation public partial class KafkaException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/KafkaFuture.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/KafkaFuture.cs index ea1be37b8..b013b55cc 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/KafkaFuture.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/KafkaFuture.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,294 @@ namespace Org.Apache.Kafka.Common { - #region KafkaFuture + #region KafkaFuture declaration + /// + /// + /// + public partial class KafkaFuture : Java.Util.Concurrent.Future + { + const string _bridgeClassName = "org.apache.kafka.common.KafkaFuture"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("KafkaFuture 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 KafkaFuture() { } + /// + /// 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("KafkaFuture 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 KafkaFuture(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 + #region BaseFunction declaration + /// + /// + /// + public partial class BaseFunction : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.KafkaFuture$BaseFunction"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("BaseFunction 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 BaseFunction() { } + /// + /// 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("BaseFunction 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 BaseFunction(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 BaseFunction declaration + /// + /// + /// + /// + /// + public partial class BaseFunction : MASES.JCOBridge.C2JBridge.JVMBridgeBase> + { + const string _bridgeClassName = "org.apache.kafka.common.KafkaFuture$BaseFunction"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("BaseFunction 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 BaseFunction() { } + /// + /// 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("BaseFunction 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 BaseFunction(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 BiConsumer declaration + /// + /// + /// + public partial class BiConsumer : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.KafkaFuture$BiConsumer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("BiConsumer 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 BiConsumer() { } + /// + /// 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("BiConsumer 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 BiConsumer(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 BiConsumer declaration + /// + /// + /// + /// + /// + public partial class BiConsumer : MASES.JCOBridge.C2JBridge.JVMBridgeBase> + { + const string _bridgeClassName = "org.apache.kafka.common.KafkaFuture$BiConsumer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("BiConsumer 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 BiConsumer() { } + /// + /// 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("BiConsumer 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 BiConsumer(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 + + + } + #endregion + + #region KafkaFuture declaration + /// + /// + /// + /// + public partial class KafkaFuture : Java.Util.Concurrent.Future + { + const string _bridgeClassName = "org.apache.kafka.common.KafkaFuture"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("KafkaFuture 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 KafkaFuture() { } + /// + /// 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("KafkaFuture 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 KafkaFuture(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 KafkaFuture implementation public partial class KafkaFuture { #region Constructors @@ -160,7 +447,7 @@ public object GetNow(object arg0) #endregion #region Nested classes - #region BaseFunction + #region BaseFunction implementation public partial class BaseFunction { #region Constructors @@ -200,7 +487,7 @@ public object Apply(object arg0) } #endregion - #region BaseFunction + #region BaseFunction implementation public partial class BaseFunction { #region Constructors @@ -244,7 +531,7 @@ public B Apply(A arg0) } #endregion - #region BiConsumer + #region BiConsumer implementation public partial class BiConsumer { #region Constructors @@ -284,7 +571,7 @@ public void Accept(object arg0, object arg1) } #endregion - #region BiConsumer + #region BiConsumer implementation public partial class BiConsumer { #region Constructors @@ -335,7 +622,7 @@ public void Accept(A arg0, B arg1) } #endregion - #region KafkaFuture + #region KafkaFuture implementation public partial class KafkaFuture { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Memory/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Memory/AllPackageClasses.cs deleted file mode 100644 index 6c35ddbc0..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Memory/AllPackageClasses.cs +++ /dev/null @@ -1,168 +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.Common.Memory -{ - #region GarbageCollectedMemoryPool - /// - /// - /// - public partial class GarbageCollectedMemoryPool : Org.Apache.Kafka.Common.Memory.SimpleMemoryPool - { - const string _bridgeClassName = "org.apache.kafka.common.memory.GarbageCollectedMemoryPool"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public GarbageCollectedMemoryPool() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public GarbageCollectedMemoryPool(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 MemoryPool - /// - /// - /// - public partial class MemoryPool : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.memory.MemoryPool"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("MemoryPool 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 MemoryPool() { } - /// - /// 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("MemoryPool 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 MemoryPool(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 SimpleMemoryPool - /// - /// - /// - public partial class SimpleMemoryPool : Org.Apache.Kafka.Common.Memory.MemoryPool - { - const string _bridgeClassName = "org.apache.kafka.common.memory.SimpleMemoryPool"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public SimpleMemoryPool() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public SimpleMemoryPool(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/Common/Memory/GarbageCollectedMemoryPool.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Memory/GarbageCollectedMemoryPool.cs index 260867687..6fc6c5e98 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Memory/GarbageCollectedMemoryPool.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Memory/GarbageCollectedMemoryPool.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.Common.Memory { - #region GarbageCollectedMemoryPool + #region GarbageCollectedMemoryPool declaration + /// + /// + /// + public partial class GarbageCollectedMemoryPool : Org.Apache.Kafka.Common.Memory.SimpleMemoryPool + { + const string _bridgeClassName = "org.apache.kafka.common.memory.GarbageCollectedMemoryPool"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public GarbageCollectedMemoryPool() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public GarbageCollectedMemoryPool(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 GarbageCollectedMemoryPool implementation public partial class GarbageCollectedMemoryPool { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Memory/MemoryPool.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Memory/MemoryPool.cs index 2eb162178..50d35e3fd 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Memory/MemoryPool.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Memory/MemoryPool.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.Common.Memory { + #region MemoryPool declaration + /// + /// + /// + public partial class MemoryPool : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.memory.MemoryPool"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("MemoryPool 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 MemoryPool() { } + /// + /// 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("MemoryPool 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 MemoryPool(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 IMemoryPool /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +90,7 @@ public partial interface IMemoryPool } #endregion - #region MemoryPool + #region MemoryPool implementation public partial class MemoryPool : Org.Apache.Kafka.Common.Memory.IMemoryPool { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Memory/SimpleMemoryPool.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Memory/SimpleMemoryPool.cs index 9638347bd..5aaba342c 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Memory/SimpleMemoryPool.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Memory/SimpleMemoryPool.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.Common.Memory { - #region SimpleMemoryPool + #region SimpleMemoryPool declaration + /// + /// + /// + public partial class SimpleMemoryPool : Org.Apache.Kafka.Common.Memory.MemoryPool + { + const string _bridgeClassName = "org.apache.kafka.common.memory.SimpleMemoryPool"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public SimpleMemoryPool() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public SimpleMemoryPool(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 SimpleMemoryPool implementation public partial class SimpleMemoryPool { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/MessageFormatter.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/MessageFormatter.cs index 511aa9e93..333f033e0 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/MessageFormatter.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/MessageFormatter.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.Common { + #region MessageFormatter declaration + /// + /// + /// + public partial class MessageFormatter : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.MessageFormatter"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("MessageFormatter 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 MessageFormatter() { } + /// + /// 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("MessageFormatter 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 MessageFormatter(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 IMessageFormatter /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +90,7 @@ public partial interface IMessageFormatter } #endregion - #region MessageFormatter + #region MessageFormatter implementation public partial class MessageFormatter : Org.Apache.Kafka.Common.IMessageFormatter, Org.Apache.Kafka.Common.IConfigurable, Java.Io.ICloseable { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metric.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metric.cs index c9960313c..eb2b3234d 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metric.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metric.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.Common { + #region Metric declaration + /// + /// + /// + public partial class Metric : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.Metric"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("Metric 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 Metric() { } + /// + /// 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("Metric 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 Metric(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 IMetric /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +90,7 @@ public partial interface IMetric } #endregion - #region Metric + #region Metric implementation public partial class Metric : Org.Apache.Kafka.Common.IMetric { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/MetricName.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/MetricName.cs index 8bfa297f6..151b17a63 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/MetricName.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/MetricName.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.Common { - #region MetricName + #region MetricName declaration + /// + /// + /// + public partial class MetricName : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.MetricName"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public MetricName() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public MetricName(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 MetricName implementation public partial class MetricName { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/MetricNameTemplate.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/MetricNameTemplate.cs index 13ee3b027..4c3a36f30 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/MetricNameTemplate.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/MetricNameTemplate.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.Common { - #region MetricNameTemplate + #region MetricNameTemplate declaration + /// + /// + /// + public partial class MetricNameTemplate : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.MetricNameTemplate"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public MetricNameTemplate() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public MetricNameTemplate(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 MetricNameTemplate implementation public partial class MetricNameTemplate { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/AllPackageClasses.cs deleted file mode 100644 index 5fc3481b6..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/AllPackageClasses.cs +++ /dev/null @@ -1,945 +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.Common.Metrics -{ - #region CompoundStat - /// - /// - /// - public partial class CompoundStat : Org.Apache.Kafka.Common.Metrics.Stat - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.CompoundStat"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("CompoundStat 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 CompoundStat() { } - /// - /// 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("CompoundStat 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 CompoundStat(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 - #region NamedMeasurable - /// - /// - /// - public partial class NamedMeasurable : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.CompoundStat$NamedMeasurable"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public NamedMeasurable() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public NamedMeasurable(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 Gauge - /// - /// - /// - public partial class Gauge : Org.Apache.Kafka.Common.Metrics.MetricValueProvider - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.Gauge"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("Gauge 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 Gauge() { } - /// - /// 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("Gauge 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 Gauge(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 Gauge - /// - /// - /// - /// - public partial class Gauge : Org.Apache.Kafka.Common.Metrics.MetricValueProvider - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.Gauge"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("Gauge 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 Gauge() { } - /// - /// 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("Gauge 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 Gauge(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 JmxReporter - /// - /// - /// - public partial class JmxReporter : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.JmxReporter"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public JmxReporter() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public JmxReporter(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 KafkaMetric - /// - /// - /// - public partial class KafkaMetric : Org.Apache.Kafka.Common.Metric - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.KafkaMetric"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public KafkaMetric() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public KafkaMetric(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 KafkaMetricsContext - /// - /// - /// - public partial class KafkaMetricsContext : Org.Apache.Kafka.Common.Metrics.MetricsContext - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.KafkaMetricsContext"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public KafkaMetricsContext() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public KafkaMetricsContext(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 Measurable - /// - /// - /// - public partial class Measurable : Org.Apache.Kafka.Common.Metrics.MetricValueProvider - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.Measurable"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("Measurable 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 Measurable() { } - /// - /// 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("Measurable 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 Measurable(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 MeasurableStat - /// - /// - /// - public partial class MeasurableStat : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.MeasurableStat"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("MeasurableStat 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 MeasurableStat() { } - /// - /// 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("MeasurableStat 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 MeasurableStat(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 MetricConfig - /// - /// - /// - public partial class MetricConfig : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.MetricConfig"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public MetricConfig() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public MetricConfig(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 Metrics - /// - /// - /// - public partial class Metrics : Java.Io.Closeable - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.Metrics"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Metrics() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Metrics(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 MetricsContext - /// - /// - /// - public partial class MetricsContext : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.MetricsContext"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("MetricsContext 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 MetricsContext() { } - /// - /// 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("MetricsContext 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 MetricsContext(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 MetricsReporter - /// - /// - /// - public partial class MetricsReporter : MASES.JCOBridge.C2JBridge.JVMBridgeListener - { - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public MetricsReporter() { InitializeHandlers(); } - - const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.common.metrics.MetricsReporter"; - 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; - - - // TODO: complete the class - - } - #endregion - - #region MetricsReporterDirect - /// - /// Direct override of or its generic type if there is one - /// - public partial class MetricsReporterDirect : MetricsReporter - { - /// - /// - /// - public override bool AutoInit => false; - - /// - protected override void InitializeHandlers() { } - - const string _bridgeClassName = "org.apache.kafka.common.metrics.MetricsReporter"; - 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; - } - #endregion - - #region MetricValueProvider - /// - /// - /// - public partial class MetricValueProvider : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.MetricValueProvider"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("MetricValueProvider 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 MetricValueProvider() { } - /// - /// 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("MetricValueProvider 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 MetricValueProvider(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 MetricValueProvider - /// - /// - /// - /// - public partial class MetricValueProvider : MASES.JCOBridge.C2JBridge.JVMBridgeBase> - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.MetricValueProvider"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("MetricValueProvider 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 MetricValueProvider() { } - /// - /// 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("MetricValueProvider 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 MetricValueProvider(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 Quota - /// - /// - /// - public partial class Quota : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.Quota"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Quota() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Quota(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 QuotaViolationException - /// - /// - /// - public partial class QuotaViolationException : Org.Apache.Kafka.Common.KafkaException - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.QuotaViolationException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region Sensor - /// - /// - /// - public partial class Sensor : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.Sensor"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Sensor() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Sensor(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 RecordingLevel - /// - /// - /// - public partial class RecordingLevel : Java.Lang.Enum - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.Sensor$RecordingLevel"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public RecordingLevel() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public RecordingLevel(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 Stat - /// - /// - /// - public partial class Stat : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.Stat"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("Stat 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 Stat() { } - /// - /// 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("Stat 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 Stat(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 - - - -} \ No newline at end of file diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/CompoundStat.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/CompoundStat.cs index fd728c13d..7717b7493 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/CompoundStat.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/CompoundStat.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,98 @@ namespace Org.Apache.Kafka.Common.Metrics { + #region CompoundStat declaration + /// + /// + /// + public partial class CompoundStat : Org.Apache.Kafka.Common.Metrics.Stat + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.CompoundStat"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("CompoundStat 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 CompoundStat() { } + /// + /// 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("CompoundStat 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 CompoundStat(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 + #region NamedMeasurable declaration + /// + /// + /// + public partial class NamedMeasurable : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.CompoundStat$NamedMeasurable"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public NamedMeasurable() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public NamedMeasurable(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 ICompoundStat /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +135,7 @@ public partial interface ICompoundStat : Org.Apache.Kafka.Common.Metrics.IStat } #endregion - #region CompoundStat + #region CompoundStat implementation public partial class CompoundStat : Org.Apache.Kafka.Common.Metrics.ICompoundStat { #region Constructors @@ -75,7 +167,7 @@ public partial class CompoundStat : Org.Apache.Kafka.Common.Metrics.ICompoundSta #endregion #region Nested classes - #region NamedMeasurable + #region NamedMeasurable implementation public partial class NamedMeasurable { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Gauge.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Gauge.cs index 6cbba7a11..865a2fb68 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Gauge.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Gauge.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.Common.Metrics { - #region Gauge + #region Gauge declaration + /// + /// + /// + public partial class Gauge : Org.Apache.Kafka.Common.Metrics.MetricValueProvider + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.Gauge"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("Gauge 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 Gauge() { } + /// + /// 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("Gauge 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 Gauge(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 Gauge declaration + /// + /// + /// + /// + public partial class Gauge : Org.Apache.Kafka.Common.Metrics.MetricValueProvider + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.Gauge"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("Gauge 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 Gauge() { } + /// + /// 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("Gauge 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 Gauge(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 Gauge implementation public partial class Gauge { #region Constructors @@ -84,7 +179,7 @@ public partial interface IGauge : Org.Apache.Kafka.Common.Metrics.IMetricValu } #endregion - #region Gauge + #region Gauge implementation public partial class Gauge : Org.Apache.Kafka.Common.Metrics.IGauge { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/JmxReporter.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/JmxReporter.cs index c157594ec..bdf2882e2 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/JmxReporter.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/JmxReporter.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.Common.Metrics { - #region JmxReporter + #region JmxReporter declaration + /// + /// + /// + public partial class JmxReporter : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.JmxReporter"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public JmxReporter() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public JmxReporter(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 JmxReporter implementation public partial class JmxReporter { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/KafkaMetric.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/KafkaMetric.cs index 09fde73e1..5f1dd8999 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/KafkaMetric.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/KafkaMetric.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.Common.Metrics { - #region KafkaMetric + #region KafkaMetric declaration + /// + /// + /// + public partial class KafkaMetric : Org.Apache.Kafka.Common.Metric + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.KafkaMetric"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public KafkaMetric() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public KafkaMetric(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 KafkaMetric implementation public partial class KafkaMetric { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/KafkaMetricsContext.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/KafkaMetricsContext.cs index 18219d47d..b6d26b9bf 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/KafkaMetricsContext.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/KafkaMetricsContext.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.Common.Metrics { - #region KafkaMetricsContext + #region KafkaMetricsContext declaration + /// + /// + /// + public partial class KafkaMetricsContext : Org.Apache.Kafka.Common.Metrics.MetricsContext + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.KafkaMetricsContext"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public KafkaMetricsContext() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public KafkaMetricsContext(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 KafkaMetricsContext implementation public partial class KafkaMetricsContext { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Measurable.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Measurable.cs index 72290426d..09211361f 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Measurable.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Measurable.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.Common.Metrics { + #region Measurable declaration + /// + /// + /// + public partial class Measurable : Org.Apache.Kafka.Common.Metrics.MetricValueProvider + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.Measurable"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("Measurable 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 Measurable() { } + /// + /// 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("Measurable 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 Measurable(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 IMeasurable /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +90,7 @@ public partial interface IMeasurable : Org.Apache.Kafka.Common.Metrics.IMetricVa } #endregion - #region Measurable + #region Measurable implementation public partial class Measurable : Org.Apache.Kafka.Common.Metrics.IMeasurable { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/MeasurableStat.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/MeasurableStat.cs index 7c4c6115d..d810c98e1 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/MeasurableStat.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/MeasurableStat.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.Common.Metrics { + #region MeasurableStat declaration + /// + /// + /// + public partial class MeasurableStat : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.MeasurableStat"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("MeasurableStat 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 MeasurableStat() { } + /// + /// 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("MeasurableStat 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 MeasurableStat(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 IMeasurableStat /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +90,7 @@ public partial interface IMeasurableStat } #endregion - #region MeasurableStat + #region MeasurableStat implementation public partial class MeasurableStat : Org.Apache.Kafka.Common.Metrics.IMeasurableStat, Org.Apache.Kafka.Common.Metrics.IStat, Org.Apache.Kafka.Common.Metrics.IMeasurable { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/MetricConfig.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/MetricConfig.cs index 040edbe06..b7401dce6 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/MetricConfig.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/MetricConfig.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.Common.Metrics { - #region MetricConfig + #region MetricConfig declaration + /// + /// + /// + public partial class MetricConfig : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.MetricConfig"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public MetricConfig() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public MetricConfig(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 MetricConfig implementation public partial class MetricConfig { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/MetricValueProvider.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/MetricValueProvider.cs index 195c8ce0a..3abe32831 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/MetricValueProvider.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/MetricValueProvider.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.Common.Metrics { - #region MetricValueProvider + #region MetricValueProvider declaration + /// + /// + /// + public partial class MetricValueProvider : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.MetricValueProvider"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("MetricValueProvider 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 MetricValueProvider() { } + /// + /// 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("MetricValueProvider 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 MetricValueProvider(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 MetricValueProvider declaration + /// + /// + /// + /// + public partial class MetricValueProvider : MASES.JCOBridge.C2JBridge.JVMBridgeBase> + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.MetricValueProvider"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("MetricValueProvider 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 MetricValueProvider() { } + /// + /// 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("MetricValueProvider 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 MetricValueProvider(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 MetricValueProvider implementation public partial class MetricValueProvider { #region Constructors @@ -74,7 +169,7 @@ public partial interface IMetricValueProvider } #endregion - #region MetricValueProvider + #region MetricValueProvider implementation public partial class MetricValueProvider : Org.Apache.Kafka.Common.Metrics.IMetricValueProvider { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Metrics.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Metrics.cs index d755cc96c..6e4557992 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Metrics.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Metrics.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.Common.Metrics { - #region Metrics + #region Metrics declaration + /// + /// + /// + public partial class Metrics : Java.Io.Closeable + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.Metrics"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Metrics() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Metrics(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 Metrics implementation public partial class Metrics { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/MetricsContext.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/MetricsContext.cs index 3feef7eb5..c82739c1e 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/MetricsContext.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/MetricsContext.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.Common.Metrics { + #region MetricsContext declaration + /// + /// + /// + public partial class MetricsContext : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.MetricsContext"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("MetricsContext 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 MetricsContext() { } + /// + /// 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("MetricsContext 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 MetricsContext(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 IMetricsContext /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +90,7 @@ public partial interface IMetricsContext } #endregion - #region MetricsContext + #region MetricsContext implementation public partial class MetricsContext : Org.Apache.Kafka.Common.Metrics.IMetricsContext { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/MetricsReporter.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/MetricsReporter.cs index 744e891f0..480977df0 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/MetricsReporter.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/MetricsReporter.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,73 @@ namespace Org.Apache.Kafka.Common.Metrics { + #region MetricsReporter declaration + /// + /// + /// + public partial class MetricsReporter : MASES.JCOBridge.C2JBridge.JVMBridgeListener + { + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public MetricsReporter() { InitializeHandlers(); } + + const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.common.metrics.MetricsReporter"; + private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = 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; + + + // TODO: complete the class + + } + #endregion + + #region MetricsReporterDirect declaration + /// + /// Direct override of or its generic type if there is one + /// + public partial class MetricsReporterDirect : MetricsReporter + { + /// + /// + /// + public override bool AutoInit => false; + + /// + protected override void InitializeHandlers() { } + + const string _bridgeClassName = "org.apache.kafka.common.metrics.MetricsReporter"; + 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; + } + #endregion + #region IMetricsReporter /// /// .NET interface for org.mases.knet.generated.org.apache.kafka.common.metrics.MetricsReporter implementing @@ -43,7 +110,7 @@ public partial interface IMetricsReporter } #endregion - #region MetricsReporter + #region MetricsReporter implementation public partial class MetricsReporter : Org.Apache.Kafka.Common.Metrics.IMetricsReporter, Org.Apache.Kafka.Common.IReconfigurable, Java.Lang.IAutoCloseable { #region Constructors @@ -68,15 +135,15 @@ public partial class MetricsReporter : Org.Apache.Kafka.Common.Metrics.IMetricsR /// protected virtual void InitializeHandlers() { - AddEventHandler("configure", new global::System.EventHandler>>>(ConfigureEventHandler)); - AddEventHandler("close", new global::System.EventHandler>(CloseEventHandler)); - AddEventHandler("init", new global::System.EventHandler>>>(InitEventHandler)); - AddEventHandler("metricChange", new global::System.EventHandler>>(MetricChangeEventHandler)); - AddEventHandler("metricRemoval", new global::System.EventHandler>>(MetricRemovalEventHandler)); - AddEventHandler("reconfigurableConfigs", new global::System.EventHandler>(ReconfigurableConfigsEventHandler)); - AddEventHandler("contextChange", new global::System.EventHandler>>(ContextChangeEventHandler)); - AddEventHandler("reconfigure", new global::System.EventHandler>>>(ReconfigureEventHandler)); - AddEventHandler("validateReconfiguration", new global::System.EventHandler>>>(ValidateReconfigurationEventHandler)); + AddEventHandler("configure", new global::System.EventHandler>>(ConfigureEventHandler)); + AddEventHandler("close", new global::System.EventHandler>>(CloseEventHandler)); + AddEventHandler("init", new global::System.EventHandler>>(InitEventHandler)); + AddEventHandler("metricChange", new global::System.EventHandler>>(MetricChangeEventHandler)); + AddEventHandler("metricRemoval", new global::System.EventHandler>>(MetricRemovalEventHandler)); + AddEventHandler("reconfigurableConfigs", new global::System.EventHandler>>(ReconfigurableConfigsEventHandler)); + AddEventHandler("contextChange", new global::System.EventHandler>>(ContextChangeEventHandler)); + AddEventHandler("reconfigure", new global::System.EventHandler>>(ReconfigureEventHandler)); + AddEventHandler("validateReconfiguration", new global::System.EventHandler>>(ValidateReconfigurationEventHandler)); } @@ -86,10 +153,13 @@ protected virtual void InitializeHandlers() /// If has a value it takes precedence over corresponding class method public global::System.Action> OnConfigure { get; set; } = null; - void ConfigureEventHandler(object sender, CLRListenerEventArgs>> data) + bool hasOverrideConfigure = true; + void ConfigureEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideConfigure = true; var methodToExecute = (OnConfigure != null) ? OnConfigure : Configure; - methodToExecute.Invoke(data.EventData.TypedEventData); + methodToExecute.Invoke(data.EventData.GetAt>(0)); + data.EventData.TypedEventData.HasOverride = hasOverrideConfigure; } /// @@ -98,7 +168,7 @@ void ConfigureEventHandler(object sender, CLRListenerEventArgs public virtual void Configure(Java.Util.Map arg0) { - + hasOverrideConfigure = false; } /// @@ -107,10 +177,13 @@ public virtual void Configure(Java.Util.Map arg0) /// If has a value it takes precedence over corresponding class method public global::System.Action OnClose { get; set; } = null; - void CloseEventHandler(object sender, CLRListenerEventArgs data) + bool hasOverrideClose = true; + void CloseEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideClose = true; var methodToExecute = (OnClose != null) ? OnClose : Close; methodToExecute.Invoke(); + data.EventData.TypedEventData.HasOverride = hasOverrideClose; } /// @@ -118,7 +191,7 @@ void CloseEventHandler(object sender, CLRListenerEventArgs data) /// public virtual void Close() { - + hasOverrideClose = false; } /// @@ -127,10 +200,13 @@ public virtual void Close() /// If has a value it takes precedence over corresponding class method public global::System.Action> OnInit { get; set; } = null; - void InitEventHandler(object sender, CLRListenerEventArgs>> data) + bool hasOverrideInit = true; + void InitEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideInit = true; var methodToExecute = (OnInit != null) ? OnInit : Init; - methodToExecute.Invoke(data.EventData.TypedEventData); + methodToExecute.Invoke(data.EventData.GetAt>(0)); + data.EventData.TypedEventData.HasOverride = hasOverrideInit; } /// @@ -139,7 +215,7 @@ void InitEventHandler(object sender, CLRListenerEventArgs public virtual void Init(Java.Util.List arg0) { - + hasOverrideInit = false; } /// @@ -148,10 +224,13 @@ public virtual void Init(Java.Util.ListIf has a value it takes precedence over corresponding class method public global::System.Action OnMetricChange { get; set; } = null; - void MetricChangeEventHandler(object sender, CLRListenerEventArgs> data) + bool hasOverrideMetricChange = true; + void MetricChangeEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideMetricChange = true; var methodToExecute = (OnMetricChange != null) ? OnMetricChange : MetricChange; - methodToExecute.Invoke(data.EventData.TypedEventData); + methodToExecute.Invoke(data.EventData.GetAt(0)); + data.EventData.TypedEventData.HasOverride = hasOverrideMetricChange; } /// @@ -160,7 +239,7 @@ void MetricChangeEventHandler(object sender, CLRListenerEventArgs public virtual void MetricChange(Org.Apache.Kafka.Common.Metrics.KafkaMetric arg0) { - + hasOverrideMetricChange = false; } /// @@ -169,10 +248,13 @@ public virtual void MetricChange(Org.Apache.Kafka.Common.Metrics.KafkaMetric arg /// If has a value it takes precedence over corresponding class method public global::System.Action OnMetricRemoval { get; set; } = null; - void MetricRemovalEventHandler(object sender, CLRListenerEventArgs> data) + bool hasOverrideMetricRemoval = true; + void MetricRemovalEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideMetricRemoval = true; var methodToExecute = (OnMetricRemoval != null) ? OnMetricRemoval : MetricRemoval; - methodToExecute.Invoke(data.EventData.TypedEventData); + methodToExecute.Invoke(data.EventData.GetAt(0)); + data.EventData.TypedEventData.HasOverride = hasOverrideMetricRemoval; } /// @@ -181,7 +263,7 @@ void MetricRemovalEventHandler(object sender, CLRListenerEventArgs public virtual void MetricRemoval(Org.Apache.Kafka.Common.Metrics.KafkaMetric arg0) { - + hasOverrideMetricRemoval = false; } /// /// @@ -199,11 +281,13 @@ public virtual void MetricRemoval(Org.Apache.Kafka.Common.Metrics.KafkaMetric ar /// If has a value it takes precedence over corresponding class method public global::System.Func> OnReconfigurableConfigs { get; set; } = null; - void ReconfigurableConfigsEventHandler(object sender, CLRListenerEventArgs data) + bool hasOverrideReconfigurableConfigs = true; + void ReconfigurableConfigsEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideReconfigurableConfigs = true; var methodToExecute = (OnReconfigurableConfigs != null) ? OnReconfigurableConfigs : ReconfigurableConfigs; var executionResult = methodToExecute.Invoke(); - data.SetReturnValue(executionResult); + data.EventData.TypedEventData.SetReturnData(hasOverrideReconfigurableConfigs, executionResult); } /// @@ -213,7 +297,7 @@ void ReconfigurableConfigsEventHandler(object sender, CLRListenerEventArgsThe method invokes the default implementation in the JVM interface using ; override the method to implement a different behavior public virtual Java.Util.Set ReconfigurableConfigs() { - return ReconfigurableConfigsDefault(); + hasOverrideReconfigurableConfigs = false; return default; } /// /// @@ -231,10 +315,13 @@ public void ContextChangeDefault(Org.Apache.Kafka.Common.Metrics.MetricsContext /// If has a value it takes precedence over corresponding class method public global::System.Action OnContextChange { get; set; } = null; - void ContextChangeEventHandler(object sender, CLRListenerEventArgs> data) + bool hasOverrideContextChange = true; + void ContextChangeEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideContextChange = true; var methodToExecute = (OnContextChange != null) ? OnContextChange : ContextChange; - methodToExecute.Invoke(data.EventData.TypedEventData); + methodToExecute.Invoke(data.EventData.GetAt(0)); + data.EventData.TypedEventData.HasOverride = hasOverrideContextChange; } /// @@ -244,7 +331,7 @@ void ContextChangeEventHandler(object sender, CLRListenerEventArgsThe method invokes the default implementation in the JVM interface using ; override the method to implement a different behavior public virtual void ContextChange(Org.Apache.Kafka.Common.Metrics.MetricsContext arg0) { - ContextChangeDefault(arg0); + hasOverrideContextChange = false; } /// /// @@ -262,10 +349,13 @@ public void ReconfigureDefault(Java.Util.Map arg0) /// If has a value it takes precedence over corresponding class method public global::System.Action> OnReconfigure { get; set; } = null; - void ReconfigureEventHandler(object sender, CLRListenerEventArgs>> data) + bool hasOverrideReconfigure = true; + void ReconfigureEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideReconfigure = true; var methodToExecute = (OnReconfigure != null) ? OnReconfigure : Reconfigure; - methodToExecute.Invoke(data.EventData.TypedEventData); + methodToExecute.Invoke(data.EventData.GetAt>(0)); + data.EventData.TypedEventData.HasOverride = hasOverrideReconfigure; } /// @@ -275,7 +365,7 @@ void ReconfigureEventHandler(object sender, CLRListenerEventArgsThe method invokes the default implementation in the JVM interface using ; override the method to implement a different behavior public virtual void Reconfigure(Java.Util.Map arg0) { - ReconfigureDefault(arg0); + hasOverrideReconfigure = false; } /// /// @@ -294,10 +384,13 @@ public void ValidateReconfigurationDefault(Java.Util.MapIf has a value it takes precedence over corresponding class method public global::System.Action> OnValidateReconfiguration { get; set; } = null; - void ValidateReconfigurationEventHandler(object sender, CLRListenerEventArgs>> data) + bool hasOverrideValidateReconfiguration = true; + void ValidateReconfigurationEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideValidateReconfiguration = true; var methodToExecute = (OnValidateReconfiguration != null) ? OnValidateReconfiguration : ValidateReconfiguration; - methodToExecute.Invoke(data.EventData.TypedEventData); + methodToExecute.Invoke(data.EventData.GetAt>(0)); + data.EventData.TypedEventData.HasOverride = hasOverrideValidateReconfiguration; } /// @@ -308,7 +401,7 @@ void ValidateReconfigurationEventHandler(object sender, CLRListenerEventArgsThe method invokes the default implementation in the JVM interface using ; override the method to implement a different behavior public virtual void ValidateReconfiguration(Java.Util.Map arg0) { - ValidateReconfigurationDefault(arg0); + hasOverrideValidateReconfiguration = false; } #endregion @@ -321,7 +414,7 @@ public virtual void ValidateReconfiguration(Java.Util.Map + /// + /// + public partial class Quota : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.Quota"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Quota() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Quota(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 Quota implementation public partial class Quota { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/QuotaViolationException.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/QuotaViolationException.cs index da7677454..9b1b7f8e4 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/QuotaViolationException.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/QuotaViolationException.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,24 @@ namespace Org.Apache.Kafka.Common.Metrics { - #region QuotaViolationException + #region QuotaViolationException declaration + /// + /// + /// + public partial class QuotaViolationException : Org.Apache.Kafka.Common.KafkaException + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.QuotaViolationException"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + #region QuotaViolationException implementation public partial class QuotaViolationException { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Sensor.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Sensor.cs index d1668b333..e3306ab6c 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Sensor.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Sensor.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.Common.Metrics { - #region Sensor + #region Sensor declaration + /// + /// + /// + public partial class Sensor : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.Sensor"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Sensor() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Sensor(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 RecordingLevel declaration + /// + /// + /// + public partial class RecordingLevel : Java.Lang.Enum + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.Sensor$RecordingLevel"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public RecordingLevel() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public RecordingLevel(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 Sensor implementation public partial class Sensor { #region Constructors @@ -170,7 +260,7 @@ public void Record(double arg0) #endregion #region Nested classes - #region RecordingLevel + #region RecordingLevel implementation public partial class RecordingLevel { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stat.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stat.cs index ea608433d..628d8d91b 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stat.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stat.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.Common.Metrics { + #region Stat declaration + /// + /// + /// + public partial class Stat : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.Stat"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("Stat 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 Stat() { } + /// + /// 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("Stat 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 Stat(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 IStat /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +90,7 @@ public partial interface IStat } #endregion - #region Stat + #region Stat implementation public partial class Stat : Org.Apache.Kafka.Common.Metrics.IStat { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/AllPackageClasses.cs deleted file mode 100644 index 660bbf0f0..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/AllPackageClasses.cs +++ /dev/null @@ -1,1025 +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.Common.Metrics.Stats -{ - #region Avg - /// - /// - /// - public partial class Avg : Org.Apache.Kafka.Common.Metrics.Stats.SampledStat - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Avg"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Avg() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Avg(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 CumulativeCount - /// - /// - /// - public partial class CumulativeCount : Org.Apache.Kafka.Common.Metrics.Stats.CumulativeSum - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.CumulativeCount"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public CumulativeCount() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public CumulativeCount(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 CumulativeSum - /// - /// - /// - public partial class CumulativeSum : Org.Apache.Kafka.Common.Metrics.MeasurableStat - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.CumulativeSum"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public CumulativeSum() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public CumulativeSum(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 Frequencies - /// - /// - /// - public partial class Frequencies : Org.Apache.Kafka.Common.Metrics.Stats.SampledStat - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Frequencies"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Frequencies() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Frequencies(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 Frequency - /// - /// - /// - public partial class Frequency : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Frequency"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Frequency() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Frequency(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 Histogram - /// - /// - /// - public partial class Histogram : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Histogram"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Histogram() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Histogram(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 BinScheme - /// - /// - /// - public partial class BinScheme : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Histogram$BinScheme"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("BinScheme 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 BinScheme() { } - /// - /// 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("BinScheme 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 BinScheme(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 ConstantBinScheme - /// - /// - /// - public partial class ConstantBinScheme : Org.Apache.Kafka.Common.Metrics.Stats.Histogram.BinScheme - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Histogram$ConstantBinScheme"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ConstantBinScheme() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ConstantBinScheme(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 LinearBinScheme - /// - /// - /// - public partial class LinearBinScheme : Org.Apache.Kafka.Common.Metrics.Stats.Histogram.BinScheme - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Histogram$LinearBinScheme"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public LinearBinScheme() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public LinearBinScheme(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 Max - /// - /// - /// - public partial class Max : Org.Apache.Kafka.Common.Metrics.Stats.SampledStat - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Max"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Max() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Max(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 Meter - /// - /// - /// - public partial class Meter : Org.Apache.Kafka.Common.Metrics.CompoundStat - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Meter"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Meter() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Meter(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 Min - /// - /// - /// - public partial class Min : Org.Apache.Kafka.Common.Metrics.Stats.SampledStat - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Min"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Min() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Min(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 Percentile - /// - /// - /// - public partial class Percentile : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Percentile"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Percentile() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Percentile(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 Percentiles - /// - /// - /// - public partial class Percentiles : Org.Apache.Kafka.Common.Metrics.Stats.SampledStat - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Percentiles"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Percentiles() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Percentiles(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 BucketSizing - /// - /// - /// - public partial class BucketSizing : Java.Lang.Enum - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Percentiles$BucketSizing"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public BucketSizing() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public BucketSizing(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 Rate - /// - /// - /// - public partial class Rate : Org.Apache.Kafka.Common.Metrics.MeasurableStat - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Rate"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Rate() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Rate(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 SampledStat - /// - /// - /// - public partial class SampledStat : Org.Apache.Kafka.Common.Metrics.MeasurableStat - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.SampledStat"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("SampledStat 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 SampledStat() { } - /// - /// 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("SampledStat 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 SampledStat(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 SimpleRate - /// - /// - /// - public partial class SimpleRate : Org.Apache.Kafka.Common.Metrics.Stats.Rate - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.SimpleRate"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public SimpleRate() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public SimpleRate(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 TokenBucket - /// - /// - /// - public partial class TokenBucket : Org.Apache.Kafka.Common.Metrics.MeasurableStat - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.TokenBucket"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public TokenBucket() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public TokenBucket(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 Value - /// - /// - /// - public partial class Value : Org.Apache.Kafka.Common.Metrics.MeasurableStat - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Value"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Value() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Value(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 WindowedCount - /// - /// - /// - public partial class WindowedCount : Org.Apache.Kafka.Common.Metrics.Stats.WindowedSum - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.WindowedCount"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public WindowedCount() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public WindowedCount(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 WindowedSum - /// - /// - /// - public partial class WindowedSum : Org.Apache.Kafka.Common.Metrics.Stats.SampledStat - { - const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.WindowedSum"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public WindowedSum() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public WindowedSum(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/Common/Metrics/Stats/Avg.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Avg.cs index 3bb1057a7..d9dd82d60 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Avg.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Avg.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.Common.Metrics.Stats { - #region Avg + #region Avg declaration + /// + /// + /// + public partial class Avg : Org.Apache.Kafka.Common.Metrics.Stats.SampledStat + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Avg"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Avg() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Avg(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 Avg implementation public partial class Avg { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/CumulativeCount.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/CumulativeCount.cs index 619ffc931..9d0a84dd2 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/CumulativeCount.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/CumulativeCount.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.Common.Metrics.Stats { - #region CumulativeCount + #region CumulativeCount declaration + /// + /// + /// + public partial class CumulativeCount : Org.Apache.Kafka.Common.Metrics.Stats.CumulativeSum + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.CumulativeCount"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public CumulativeCount() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public CumulativeCount(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 CumulativeCount implementation public partial class CumulativeCount { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/CumulativeSum.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/CumulativeSum.cs index 498f6cc5c..87c8db5f5 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/CumulativeSum.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/CumulativeSum.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.Common.Metrics.Stats { - #region CumulativeSum + #region CumulativeSum declaration + /// + /// + /// + public partial class CumulativeSum : Org.Apache.Kafka.Common.Metrics.MeasurableStat + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.CumulativeSum"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public CumulativeSum() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public CumulativeSum(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 CumulativeSum implementation public partial class CumulativeSum { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Frequencies.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Frequencies.cs index 2bef16da6..aa5117da8 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Frequencies.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Frequencies.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.Common.Metrics.Stats { - #region Frequencies + #region Frequencies declaration + /// + /// + /// + public partial class Frequencies : Org.Apache.Kafka.Common.Metrics.Stats.SampledStat + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Frequencies"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Frequencies() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Frequencies(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 Frequencies implementation public partial class Frequencies { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Frequency.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Frequency.cs index 92a749d0c..09cd91be2 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Frequency.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Frequency.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.Common.Metrics.Stats { - #region Frequency + #region Frequency declaration + /// + /// + /// + public partial class Frequency : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Frequency"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Frequency() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Frequency(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 Frequency implementation public partial class Frequency { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Histogram.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Histogram.cs index a4bfa1c5a..cca5494de 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Histogram.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Histogram.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,189 @@ namespace Org.Apache.Kafka.Common.Metrics.Stats { - #region Histogram + #region Histogram declaration + /// + /// + /// + public partial class Histogram : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Histogram"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Histogram() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Histogram(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 BinScheme declaration + /// + /// + /// + public partial class BinScheme : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Histogram$BinScheme"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("BinScheme 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 BinScheme() { } + /// + /// 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("BinScheme 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 BinScheme(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 ConstantBinScheme declaration + /// + /// + /// + public partial class ConstantBinScheme : Org.Apache.Kafka.Common.Metrics.Stats.Histogram.BinScheme + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Histogram$ConstantBinScheme"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ConstantBinScheme() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ConstantBinScheme(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 LinearBinScheme declaration + /// + /// + /// + public partial class LinearBinScheme : Org.Apache.Kafka.Common.Metrics.Stats.Histogram.BinScheme + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Histogram$LinearBinScheme"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public LinearBinScheme() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public LinearBinScheme(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 Histogram implementation public partial class Histogram { #region Constructors @@ -89,7 +271,7 @@ public void Record(double arg0) #endregion #region Nested classes - #region BinScheme + #region BinScheme implementation public partial class BinScheme { #region Constructors @@ -146,7 +328,7 @@ public int ToBin(double arg0) } #endregion - #region ConstantBinScheme + #region ConstantBinScheme implementation public partial class ConstantBinScheme { #region Constructors @@ -213,7 +395,7 @@ public int ToBin(double arg0) } #endregion - #region LinearBinScheme + #region LinearBinScheme implementation public partial class LinearBinScheme { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Max.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Max.cs index 908879b5f..43357d905 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Max.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Max.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.Common.Metrics.Stats { - #region Max + #region Max declaration + /// + /// + /// + public partial class Max : Org.Apache.Kafka.Common.Metrics.Stats.SampledStat + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Max"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Max() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Max(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 Max implementation public partial class Max { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Meter.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Meter.cs index 52cd28282..3bba216bb 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Meter.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Meter.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.Common.Metrics.Stats { - #region Meter + #region Meter declaration + /// + /// + /// + public partial class Meter : Org.Apache.Kafka.Common.Metrics.CompoundStat + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Meter"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Meter() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Meter(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 Meter implementation public partial class Meter { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Min.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Min.cs index 268a3e6ac..21da329ac 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Min.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Min.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.Common.Metrics.Stats { - #region Min + #region Min declaration + /// + /// + /// + public partial class Min : Org.Apache.Kafka.Common.Metrics.Stats.SampledStat + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Min"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Min() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Min(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 Min implementation public partial class Min { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Percentile.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Percentile.cs index de172aca1..04c05178f 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Percentile.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Percentile.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.Common.Metrics.Stats { - #region Percentile + #region Percentile declaration + /// + /// + /// + public partial class Percentile : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Percentile"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Percentile() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Percentile(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 Percentile implementation public partial class Percentile { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Percentiles.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Percentiles.cs index cda9183da..616978b0b 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Percentiles.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Percentiles.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.Common.Metrics.Stats { - #region Percentiles + #region Percentiles declaration + /// + /// + /// + public partial class Percentiles : Org.Apache.Kafka.Common.Metrics.Stats.SampledStat + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Percentiles"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Percentiles() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Percentiles(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 BucketSizing declaration + /// + /// + /// + public partial class BucketSizing : Java.Lang.Enum + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Percentiles$BucketSizing"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public BucketSizing() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public BucketSizing(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 Percentiles implementation public partial class Percentiles { #region Constructors @@ -95,7 +185,7 @@ public double Value(Org.Apache.Kafka.Common.Metrics.MetricConfig arg0, long arg1 #endregion #region Nested classes - #region BucketSizing + #region BucketSizing implementation public partial class BucketSizing { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Rate.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Rate.cs index 5f6a0db67..800158c53 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Rate.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Rate.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.Common.Metrics.Stats { - #region Rate + #region Rate declaration + /// + /// + /// + public partial class Rate : Org.Apache.Kafka.Common.Metrics.MeasurableStat + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Rate"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Rate() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Rate(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 Rate implementation public partial class Rate { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/SampledStat.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/SampledStat.cs index 115d31917..e3d25f0a8 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/SampledStat.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/SampledStat.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.Common.Metrics.Stats { - #region SampledStat + #region SampledStat declaration + /// + /// + /// + public partial class SampledStat : Org.Apache.Kafka.Common.Metrics.MeasurableStat + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.SampledStat"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("SampledStat 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 SampledStat() { } + /// + /// 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("SampledStat 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 SampledStat(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 SampledStat implementation public partial class SampledStat { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/SimpleRate.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/SimpleRate.cs index 36c50b1c7..94d54e42d 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/SimpleRate.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/SimpleRate.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.Common.Metrics.Stats { - #region SimpleRate + #region SimpleRate declaration + /// + /// + /// + public partial class SimpleRate : Org.Apache.Kafka.Common.Metrics.Stats.Rate + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.SimpleRate"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public SimpleRate() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public SimpleRate(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 SimpleRate implementation public partial class SimpleRate { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/TokenBucket.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/TokenBucket.cs index 98f8dec6d..7b4581e82 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/TokenBucket.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/TokenBucket.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.Common.Metrics.Stats { - #region TokenBucket + #region TokenBucket declaration + /// + /// + /// + public partial class TokenBucket : Org.Apache.Kafka.Common.Metrics.MeasurableStat + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.TokenBucket"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public TokenBucket() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public TokenBucket(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 TokenBucket implementation public partial class TokenBucket { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Value.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Value.cs index a4c27e383..2627563bb 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Value.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/Value.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.Common.Metrics.Stats { - #region Value + #region Value declaration + /// + /// + /// + public partial class Value : Org.Apache.Kafka.Common.Metrics.MeasurableStat + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.Value"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Value() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Value(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 Value implementation public partial class Value { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/WindowedCount.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/WindowedCount.cs index fc3ede4a9..823f7a13f 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/WindowedCount.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/WindowedCount.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.Common.Metrics.Stats { - #region WindowedCount + #region WindowedCount declaration + /// + /// + /// + public partial class WindowedCount : Org.Apache.Kafka.Common.Metrics.Stats.WindowedSum + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.WindowedCount"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public WindowedCount() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public WindowedCount(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 WindowedCount implementation public partial class WindowedCount { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/WindowedSum.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/WindowedSum.cs index 48052398f..7e40fb098 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/WindowedSum.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/WindowedSum.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.Common.Metrics.Stats { - #region WindowedSum + #region WindowedSum declaration + /// + /// + /// + public partial class WindowedSum : Org.Apache.Kafka.Common.Metrics.Stats.SampledStat + { + const string _bridgeClassName = "org.apache.kafka.common.metrics.stats.WindowedSum"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public WindowedSum() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public WindowedSum(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 WindowedSum implementation public partial class WindowedSum { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Node.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Node.cs index 528ec5563..3605dceb5 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Node.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Node.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.Common { - #region Node + #region Node declaration + /// + /// + /// + public partial class Node : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.Node"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Node() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Node(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 Node implementation public partial class Node { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/PartitionInfo.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/PartitionInfo.cs index 89fc7b3d9..a8a29d061 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/PartitionInfo.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/PartitionInfo.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.Common { - #region PartitionInfo + #region PartitionInfo declaration + /// + /// + /// + public partial class PartitionInfo : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.PartitionInfo"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public PartitionInfo() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public PartitionInfo(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 PartitionInfo implementation public partial class PartitionInfo { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Quota/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Quota/AllPackageClasses.cs deleted file mode 100644 index 95abc78b9..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Quota/AllPackageClasses.cs +++ /dev/null @@ -1,256 +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.Common.Quota -{ - #region ClientQuotaAlteration - /// - /// - /// - public partial class ClientQuotaAlteration : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.quota.ClientQuotaAlteration"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ClientQuotaAlteration() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ClientQuotaAlteration(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 Op - /// - /// - /// - public partial class Op : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.quota.ClientQuotaAlteration$Op"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Op() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Op(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 ClientQuotaEntity - /// - /// - /// - public partial class ClientQuotaEntity : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.quota.ClientQuotaEntity"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ClientQuotaEntity() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ClientQuotaEntity(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 ClientQuotaFilter - /// - /// - /// - public partial class ClientQuotaFilter : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.quota.ClientQuotaFilter"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ClientQuotaFilter() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ClientQuotaFilter(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 ClientQuotaFilterComponent - /// - /// - /// - public partial class ClientQuotaFilterComponent : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.quota.ClientQuotaFilterComponent"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ClientQuotaFilterComponent() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ClientQuotaFilterComponent(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/Common/Quota/ClientQuotaAlteration.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Quota/ClientQuotaAlteration.cs index b8e6ead51..3af3e1442 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Quota/ClientQuotaAlteration.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Quota/ClientQuotaAlteration.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.Common.Quota { - #region ClientQuotaAlteration + #region ClientQuotaAlteration declaration + /// + /// + /// + public partial class ClientQuotaAlteration : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.quota.ClientQuotaAlteration"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ClientQuotaAlteration() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ClientQuotaAlteration(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 Op declaration + /// + /// + /// + public partial class Op : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.quota.ClientQuotaAlteration$Op"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Op() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Op(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 ClientQuotaAlteration implementation public partial class ClientQuotaAlteration { #region Constructors @@ -74,7 +164,7 @@ public Org.Apache.Kafka.Common.Quota.ClientQuotaEntity Entity() #endregion #region Nested classes - #region Op + #region Op implementation public partial class Op { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Quota/ClientQuotaEntity.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Quota/ClientQuotaEntity.cs index 78a1d55d1..589ce046d 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Quota/ClientQuotaEntity.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Quota/ClientQuotaEntity.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.Common.Quota { - #region ClientQuotaEntity + #region ClientQuotaEntity declaration + /// + /// + /// + public partial class ClientQuotaEntity : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.quota.ClientQuotaEntity"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ClientQuotaEntity() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ClientQuotaEntity(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 ClientQuotaEntity implementation public partial class ClientQuotaEntity { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Quota/ClientQuotaFilter.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Quota/ClientQuotaFilter.cs index 5335703fc..f262ec843 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Quota/ClientQuotaFilter.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Quota/ClientQuotaFilter.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.Common.Quota { - #region ClientQuotaFilter + #region ClientQuotaFilter declaration + /// + /// + /// + public partial class ClientQuotaFilter : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.quota.ClientQuotaFilter"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ClientQuotaFilter() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ClientQuotaFilter(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 ClientQuotaFilter implementation public partial class ClientQuotaFilter { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Quota/ClientQuotaFilterComponent.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Quota/ClientQuotaFilterComponent.cs index 01fe172dc..acaa86cbb 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Quota/ClientQuotaFilterComponent.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Quota/ClientQuotaFilterComponent.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.Common.Quota { - #region ClientQuotaFilterComponent + #region ClientQuotaFilterComponent declaration + /// + /// + /// + public partial class ClientQuotaFilterComponent : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.quota.ClientQuotaFilterComponent"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ClientQuotaFilterComponent() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ClientQuotaFilterComponent(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 ClientQuotaFilterComponent implementation public partial class ClientQuotaFilterComponent { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Reconfigurable.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Reconfigurable.cs index f49bae20e..ce967803c 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Reconfigurable.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Reconfigurable.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.Common { + #region Reconfigurable declaration + /// + /// + /// + public partial class Reconfigurable : Org.Apache.Kafka.Common.Configurable + { + const string _bridgeClassName = "org.apache.kafka.common.Reconfigurable"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("Reconfigurable 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 Reconfigurable() { } + /// + /// 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("Reconfigurable 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 Reconfigurable(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 IReconfigurable /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +90,7 @@ public partial interface IReconfigurable : Org.Apache.Kafka.Common.IConfigurable } #endregion - #region Reconfigurable + #region Reconfigurable implementation public partial class Reconfigurable : Org.Apache.Kafka.Common.IReconfigurable { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/AbstractLegacyRecordBatch.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/AbstractLegacyRecordBatch.cs index 39dd26c0d..61cd96ac0 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/AbstractLegacyRecordBatch.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/AbstractLegacyRecordBatch.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.Common.Record { - #region AbstractLegacyRecordBatch + #region AbstractLegacyRecordBatch declaration + /// + /// + /// + public partial class AbstractLegacyRecordBatch : Org.Apache.Kafka.Common.Record.Record + { + const string _bridgeClassName = "org.apache.kafka.common.record.AbstractLegacyRecordBatch"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("AbstractLegacyRecordBatch 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 AbstractLegacyRecordBatch() { } + /// + /// 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("AbstractLegacyRecordBatch 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 AbstractLegacyRecordBatch(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 AbstractLegacyRecordBatch implementation public partial class AbstractLegacyRecordBatch { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/AllPackageClasses.cs deleted file mode 100644 index e85c50f8e..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/AllPackageClasses.cs +++ /dev/null @@ -1,1172 +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.Common.Record -{ - #region AbstractLegacyRecordBatch - /// - /// - /// - public partial class AbstractLegacyRecordBatch : Org.Apache.Kafka.Common.Record.Record - { - const string _bridgeClassName = "org.apache.kafka.common.record.AbstractLegacyRecordBatch"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("AbstractLegacyRecordBatch 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 AbstractLegacyRecordBatch() { } - /// - /// 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("AbstractLegacyRecordBatch 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 AbstractLegacyRecordBatch(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 CompressionType - /// - /// - /// - public partial class CompressionType : Java.Lang.Enum - { - const string _bridgeClassName = "org.apache.kafka.common.record.CompressionType"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("CompressionType 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 CompressionType() { } - /// - /// 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("CompressionType 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 CompressionType(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 ControlRecordType - /// - /// - /// - public partial class ControlRecordType : Java.Lang.Enum - { - const string _bridgeClassName = "org.apache.kafka.common.record.ControlRecordType"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ControlRecordType() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ControlRecordType(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 ControlRecordUtils - /// - /// - /// - public partial class ControlRecordUtils : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.record.ControlRecordUtils"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ControlRecordUtils() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ControlRecordUtils(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 DefaultRecordBatch - /// - /// - /// - public partial class DefaultRecordBatch : Org.Apache.Kafka.Common.Record.MutableRecordBatch - { - const string _bridgeClassName = "org.apache.kafka.common.record.DefaultRecordBatch"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public DefaultRecordBatch() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public DefaultRecordBatch(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 FileLogInputStream - /// - /// - /// - public partial class FileLogInputStream : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.record.FileLogInputStream"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public FileLogInputStream() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public FileLogInputStream(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 FileChannelRecordBatch - /// - /// - /// - public partial class FileChannelRecordBatch : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.record.FileLogInputStream$FileChannelRecordBatch"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("FileChannelRecordBatch 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 FileChannelRecordBatch() { } - /// - /// 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("FileChannelRecordBatch 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 FileChannelRecordBatch(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 => true; - - // TODO: complete the class - - } - #endregion - - - } - #endregion - - #region LazyDownConversionRecords - /// - /// - /// - public partial class LazyDownConversionRecords : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.record.LazyDownConversionRecords"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public LazyDownConversionRecords() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public LazyDownConversionRecords(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 LegacyRecord - /// - /// - /// - public partial class LegacyRecord : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.record.LegacyRecord"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public LegacyRecord() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public LegacyRecord(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 MemoryRecordsBuilder - /// - /// - /// - public partial class MemoryRecordsBuilder : Java.Lang.AutoCloseable - { - const string _bridgeClassName = "org.apache.kafka.common.record.MemoryRecordsBuilder"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public MemoryRecordsBuilder() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public MemoryRecordsBuilder(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 RecordsInfo - /// - /// - /// - public partial class RecordsInfo : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.record.MemoryRecordsBuilder$RecordsInfo"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public RecordsInfo() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public RecordsInfo(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 MultiRecordsSend - /// - /// - /// - public partial class MultiRecordsSend : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.record.MultiRecordsSend"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public MultiRecordsSend() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public MultiRecordsSend(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 MutableRecordBatch - /// - /// - /// - public partial class MutableRecordBatch : Org.Apache.Kafka.Common.Record.RecordBatch - { - const string _bridgeClassName = "org.apache.kafka.common.record.MutableRecordBatch"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("MutableRecordBatch 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 MutableRecordBatch() { } - /// - /// 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("MutableRecordBatch 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 MutableRecordBatch(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 Record - /// - /// - /// - public partial class Record : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.record.Record"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("Record 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 Record() { } - /// - /// 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("Record 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 Record(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 RecordBatch - /// - /// - /// - public partial class RecordBatch : Java.Lang.Iterable - { - const string _bridgeClassName = "org.apache.kafka.common.record.RecordBatch"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("RecordBatch 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 RecordBatch() { } - /// - /// 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("RecordBatch 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 RecordBatch(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 RecordConversionStats - /// - /// - /// - public partial class RecordConversionStats : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.record.RecordConversionStats"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public RecordConversionStats() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public RecordConversionStats(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 RecordsUtil - /// - /// - /// - public partial class RecordsUtil : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.record.RecordsUtil"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public RecordsUtil() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public RecordsUtil(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 RecordVersion - /// - /// - /// - public partial class RecordVersion : Java.Lang.Enum - { - const string _bridgeClassName = "org.apache.kafka.common.record.RecordVersion"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public RecordVersion() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public RecordVersion(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 RemoteLogInputStream - /// - /// - /// - public partial class RemoteLogInputStream : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.record.RemoteLogInputStream"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public RemoteLogInputStream() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public RemoteLogInputStream(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 SimpleRecord - /// - /// - /// - public partial class SimpleRecord : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.record.SimpleRecord"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public SimpleRecord() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public SimpleRecord(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 TimestampType - /// - /// - /// - public partial class TimestampType : Java.Lang.Enum - { - const string _bridgeClassName = "org.apache.kafka.common.record.TimestampType"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public TimestampType() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public TimestampType(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 TransferableRecords - /// - /// - /// - public partial class TransferableRecords : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.record.TransferableRecords"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("TransferableRecords 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 TransferableRecords() { } - /// - /// 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("TransferableRecords 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 TransferableRecords(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 UnalignedFileRecords - /// - /// - /// - public partial class UnalignedFileRecords : Org.Apache.Kafka.Common.Record.UnalignedRecords - { - const string _bridgeClassName = "org.apache.kafka.common.record.UnalignedFileRecords"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public UnalignedFileRecords() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public UnalignedFileRecords(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 UnalignedMemoryRecords - /// - /// - /// - public partial class UnalignedMemoryRecords : Org.Apache.Kafka.Common.Record.UnalignedRecords - { - const string _bridgeClassName = "org.apache.kafka.common.record.UnalignedMemoryRecords"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public UnalignedMemoryRecords() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public UnalignedMemoryRecords(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 UnalignedRecords - /// - /// - /// - public partial class UnalignedRecords : Org.Apache.Kafka.Common.Record.TransferableRecords - { - const string _bridgeClassName = "org.apache.kafka.common.record.UnalignedRecords"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("UnalignedRecords 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 UnalignedRecords() { } - /// - /// 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("UnalignedRecords 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 UnalignedRecords(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 - - - -} \ No newline at end of file diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/CompressionType.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/CompressionType.cs index 717a82b09..438ba2bc5 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/CompressionType.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/CompressionType.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.Common.Record { - #region CompressionType + #region CompressionType declaration + /// + /// + /// + public partial class CompressionType : Java.Lang.Enum + { + const string _bridgeClassName = "org.apache.kafka.common.record.CompressionType"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("CompressionType 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 CompressionType() { } + /// + /// 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("CompressionType 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 CompressionType(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 CompressionType implementation public partial class CompressionType { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/ControlRecordType.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/ControlRecordType.cs index e67d64234..6f598d9b1 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/ControlRecordType.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/ControlRecordType.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.Common.Record { - #region ControlRecordType + #region ControlRecordType declaration + /// + /// + /// + public partial class ControlRecordType : Java.Lang.Enum + { + const string _bridgeClassName = "org.apache.kafka.common.record.ControlRecordType"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ControlRecordType() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ControlRecordType(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 ControlRecordType implementation public partial class ControlRecordType { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/ControlRecordUtils.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/ControlRecordUtils.cs index c9361df69..9fa967be8 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/ControlRecordUtils.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/ControlRecordUtils.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.Common.Record { - #region ControlRecordUtils + #region ControlRecordUtils declaration + /// + /// + /// + public partial class ControlRecordUtils : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.record.ControlRecordUtils"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ControlRecordUtils() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ControlRecordUtils(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 ControlRecordUtils implementation public partial class ControlRecordUtils { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/DefaultRecordBatch.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/DefaultRecordBatch.cs index 56bdb05b7..ba1358553 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/DefaultRecordBatch.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/DefaultRecordBatch.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.Common.Record { - #region DefaultRecordBatch + #region DefaultRecordBatch declaration + /// + /// + /// + public partial class DefaultRecordBatch : Org.Apache.Kafka.Common.Record.MutableRecordBatch + { + const string _bridgeClassName = "org.apache.kafka.common.record.DefaultRecordBatch"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public DefaultRecordBatch() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public DefaultRecordBatch(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 DefaultRecordBatch implementation public partial class DefaultRecordBatch { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/FileLogInputStream.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/FileLogInputStream.cs index 4566ecf12..a60def1bb 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/FileLogInputStream.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/FileLogInputStream.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,99 @@ namespace Org.Apache.Kafka.Common.Record { - #region FileLogInputStream + #region FileLogInputStream declaration + /// + /// + /// + public partial class FileLogInputStream : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.record.FileLogInputStream"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public FileLogInputStream() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public FileLogInputStream(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 FileChannelRecordBatch declaration + /// + /// + /// + public partial class FileChannelRecordBatch : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.record.FileLogInputStream$FileChannelRecordBatch"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("FileChannelRecordBatch 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 FileChannelRecordBatch() { } + /// + /// 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("FileChannelRecordBatch 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 FileChannelRecordBatch(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 => true; + + // TODO: complete the class + + } + #endregion + + + } + #endregion + + #region FileLogInputStream implementation public partial class FileLogInputStream { #region Constructors @@ -58,7 +150,7 @@ public Org.Apache.Kafka.Common.Record.RecordBatch NextBatch() #endregion #region Nested classes - #region FileChannelRecordBatch + #region FileChannelRecordBatch implementation public partial class FileChannelRecordBatch { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/LazyDownConversionRecords.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/LazyDownConversionRecords.cs index 1bb9028b4..b8adc4d29 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/LazyDownConversionRecords.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/LazyDownConversionRecords.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.Common.Record { - #region LazyDownConversionRecords + #region LazyDownConversionRecords declaration + /// + /// + /// + public partial class LazyDownConversionRecords : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.record.LazyDownConversionRecords"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public LazyDownConversionRecords() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public LazyDownConversionRecords(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 LazyDownConversionRecords implementation public partial class LazyDownConversionRecords { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/LegacyRecord.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/LegacyRecord.cs index 51a617ff9..5c6c55998 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/LegacyRecord.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/LegacyRecord.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.Common.Record { - #region LegacyRecord + #region LegacyRecord declaration + /// + /// + /// + public partial class LegacyRecord : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.record.LegacyRecord"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public LegacyRecord() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public LegacyRecord(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 LegacyRecord implementation public partial class LegacyRecord { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/MemoryRecordsBuilder.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/MemoryRecordsBuilder.cs index 565f02c4d..eaa85d05a 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/MemoryRecordsBuilder.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/MemoryRecordsBuilder.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.Common.Record { - #region MemoryRecordsBuilder + #region MemoryRecordsBuilder declaration + /// + /// + /// + public partial class MemoryRecordsBuilder : Java.Lang.AutoCloseable + { + const string _bridgeClassName = "org.apache.kafka.common.record.MemoryRecordsBuilder"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public MemoryRecordsBuilder() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public MemoryRecordsBuilder(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 RecordsInfo declaration + /// + /// + /// + public partial class RecordsInfo : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.record.MemoryRecordsBuilder$RecordsInfo"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public RecordsInfo() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public RecordsInfo(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 MemoryRecordsBuilder implementation public partial class MemoryRecordsBuilder { #region Constructors @@ -496,7 +586,7 @@ public void SetProducerState(long arg0, short arg1, int arg2, bool arg3) #endregion #region Nested classes - #region RecordsInfo + #region RecordsInfo implementation public partial class RecordsInfo { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/MultiRecordsSend.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/MultiRecordsSend.cs index fee153ed1..8169e6c1f 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/MultiRecordsSend.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/MultiRecordsSend.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.Common.Record { - #region MultiRecordsSend + #region MultiRecordsSend declaration + /// + /// + /// + public partial class MultiRecordsSend : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.record.MultiRecordsSend"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public MultiRecordsSend() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public MultiRecordsSend(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 MultiRecordsSend implementation public partial class MultiRecordsSend { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/MutableRecordBatch.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/MutableRecordBatch.cs index 8e49a2fe8..aa37703f9 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/MutableRecordBatch.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/MutableRecordBatch.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.Common.Record { + #region MutableRecordBatch declaration + /// + /// + /// + public partial class MutableRecordBatch : Org.Apache.Kafka.Common.Record.RecordBatch + { + const string _bridgeClassName = "org.apache.kafka.common.record.MutableRecordBatch"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("MutableRecordBatch 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 MutableRecordBatch() { } + /// + /// 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("MutableRecordBatch 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 MutableRecordBatch(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 IMutableRecordBatch /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +90,7 @@ public partial interface IMutableRecordBatch : Org.Apache.Kafka.Common.Record.IR } #endregion - #region MutableRecordBatch + #region MutableRecordBatch implementation public partial class MutableRecordBatch : Org.Apache.Kafka.Common.Record.IMutableRecordBatch { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/Record.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/Record.cs index 04adb06aa..88d1bdcfa 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/Record.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/Record.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.Common.Record { + #region Record declaration + /// + /// + /// + public partial class Record : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.record.Record"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("Record 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 Record() { } + /// + /// 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("Record 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 Record(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 IRecord /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +90,7 @@ public partial interface IRecord } #endregion - #region Record + #region Record implementation public partial class Record : Org.Apache.Kafka.Common.Record.IRecord { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/RecordBatch.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/RecordBatch.cs index 6d1791448..0df4d0767 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/RecordBatch.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/RecordBatch.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.Common.Record { + #region RecordBatch declaration + /// + /// + /// + public partial class RecordBatch : Java.Lang.Iterable + { + const string _bridgeClassName = "org.apache.kafka.common.record.RecordBatch"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("RecordBatch 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 RecordBatch() { } + /// + /// 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("RecordBatch 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 RecordBatch(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 IRecordBatch /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +90,7 @@ public partial interface IRecordBatch } #endregion - #region RecordBatch + #region RecordBatch implementation public partial class RecordBatch : Org.Apache.Kafka.Common.Record.IRecordBatch { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/RecordConversionStats.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/RecordConversionStats.cs index aa8f74077..eb90c868e 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/RecordConversionStats.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/RecordConversionStats.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.Common.Record { - #region RecordConversionStats + #region RecordConversionStats declaration + /// + /// + /// + public partial class RecordConversionStats : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.record.RecordConversionStats"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public RecordConversionStats() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public RecordConversionStats(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 RecordConversionStats implementation public partial class RecordConversionStats { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/RecordVersion.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/RecordVersion.cs index 70037112d..44bf112ba 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/RecordVersion.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/RecordVersion.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.Common.Record { - #region RecordVersion + #region RecordVersion declaration + /// + /// + /// + public partial class RecordVersion : Java.Lang.Enum + { + const string _bridgeClassName = "org.apache.kafka.common.record.RecordVersion"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public RecordVersion() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public RecordVersion(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 RecordVersion implementation public partial class RecordVersion { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/RecordsUtil.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/RecordsUtil.cs index 7187c1f43..9ef0a7c09 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/RecordsUtil.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/RecordsUtil.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.Common.Record { - #region RecordsUtil + #region RecordsUtil declaration + /// + /// + /// + public partial class RecordsUtil : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.record.RecordsUtil"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public RecordsUtil() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public RecordsUtil(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 RecordsUtil implementation public partial class RecordsUtil { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/RemoteLogInputStream.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/RemoteLogInputStream.cs index f64ef9eea..34930da4d 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/RemoteLogInputStream.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/RemoteLogInputStream.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.Common.Record { - #region RemoteLogInputStream + #region RemoteLogInputStream declaration + /// + /// + /// + public partial class RemoteLogInputStream : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.record.RemoteLogInputStream"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public RemoteLogInputStream() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public RemoteLogInputStream(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 RemoteLogInputStream implementation public partial class RemoteLogInputStream { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/SimpleRecord.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/SimpleRecord.cs index ae7be30b6..f8c1b3907 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/SimpleRecord.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/SimpleRecord.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.Common.Record { - #region SimpleRecord + #region SimpleRecord declaration + /// + /// + /// + public partial class SimpleRecord : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.record.SimpleRecord"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public SimpleRecord() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public SimpleRecord(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 SimpleRecord implementation public partial class SimpleRecord { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/TimestampType.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/TimestampType.cs index bc7ff9c84..ea6d1cfab 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/TimestampType.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/TimestampType.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.Common.Record { - #region TimestampType + #region TimestampType declaration + /// + /// + /// + public partial class TimestampType : Java.Lang.Enum + { + const string _bridgeClassName = "org.apache.kafka.common.record.TimestampType"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public TimestampType() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public TimestampType(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 TimestampType implementation public partial class TimestampType { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/TransferableRecords.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/TransferableRecords.cs index 7dd0de766..2ca96c6e8 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/TransferableRecords.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/TransferableRecords.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.Common.Record { + #region TransferableRecords declaration + /// + /// + /// + public partial class TransferableRecords : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.record.TransferableRecords"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("TransferableRecords 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 TransferableRecords() { } + /// + /// 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("TransferableRecords 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 TransferableRecords(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 ITransferableRecords /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +90,7 @@ public partial interface ITransferableRecords } #endregion - #region TransferableRecords + #region TransferableRecords implementation public partial class TransferableRecords : Org.Apache.Kafka.Common.Record.ITransferableRecords { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/UnalignedFileRecords.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/UnalignedFileRecords.cs index 080cdfe42..041cdce14 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/UnalignedFileRecords.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/UnalignedFileRecords.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.Common.Record { - #region UnalignedFileRecords + #region UnalignedFileRecords declaration + /// + /// + /// + public partial class UnalignedFileRecords : Org.Apache.Kafka.Common.Record.UnalignedRecords + { + const string _bridgeClassName = "org.apache.kafka.common.record.UnalignedFileRecords"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public UnalignedFileRecords() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public UnalignedFileRecords(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 UnalignedFileRecords implementation public partial class UnalignedFileRecords { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/UnalignedMemoryRecords.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/UnalignedMemoryRecords.cs index fef4c3851..4416a0651 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/UnalignedMemoryRecords.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/UnalignedMemoryRecords.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.Common.Record { - #region UnalignedMemoryRecords + #region UnalignedMemoryRecords declaration + /// + /// + /// + public partial class UnalignedMemoryRecords : Org.Apache.Kafka.Common.Record.UnalignedRecords + { + const string _bridgeClassName = "org.apache.kafka.common.record.UnalignedMemoryRecords"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public UnalignedMemoryRecords() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public UnalignedMemoryRecords(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 UnalignedMemoryRecords implementation public partial class UnalignedMemoryRecords { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/UnalignedRecords.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/UnalignedRecords.cs index 6edfe9a85..221104991 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/UnalignedRecords.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/UnalignedRecords.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.Common.Record { + #region UnalignedRecords declaration + /// + /// + /// + public partial class UnalignedRecords : Org.Apache.Kafka.Common.Record.TransferableRecords + { + const string _bridgeClassName = "org.apache.kafka.common.record.UnalignedRecords"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("UnalignedRecords 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 UnalignedRecords() { } + /// + /// 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("UnalignedRecords 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 UnalignedRecords(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 IUnalignedRecords /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +90,7 @@ public partial interface IUnalignedRecords : Org.Apache.Kafka.Common.Record.ITra } #endregion - #region UnalignedRecords + #region UnalignedRecords implementation public partial class UnalignedRecords : Org.Apache.Kafka.Common.Record.IUnalignedRecords { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Replica/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Replica/AllPackageClasses.cs deleted file mode 100644 index eb07ce628..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Replica/AllPackageClasses.cs +++ /dev/null @@ -1,399 +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.Common.Replica -{ - #region ClientMetadata - /// - /// - /// - public partial class ClientMetadata : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.replica.ClientMetadata"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("ClientMetadata 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 ClientMetadata() { } - /// - /// 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("ClientMetadata 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 ClientMetadata(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 - #region DefaultClientMetadata - /// - /// - /// - public partial class DefaultClientMetadata : Org.Apache.Kafka.Common.Replica.ClientMetadata - { - const string _bridgeClassName = "org.apache.kafka.common.replica.ClientMetadata$DefaultClientMetadata"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public DefaultClientMetadata() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public DefaultClientMetadata(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 PartitionView - /// - /// - /// - public partial class PartitionView : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.replica.PartitionView"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("PartitionView 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 PartitionView() { } - /// - /// 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("PartitionView 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 PartitionView(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 - #region DefaultPartitionView - /// - /// - /// - public partial class DefaultPartitionView : Org.Apache.Kafka.Common.Replica.PartitionView - { - const string _bridgeClassName = "org.apache.kafka.common.replica.PartitionView$DefaultPartitionView"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public DefaultPartitionView() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public DefaultPartitionView(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 RackAwareReplicaSelector - /// - /// - /// - public partial class RackAwareReplicaSelector : Org.Apache.Kafka.Common.Replica.ReplicaSelector - { - const string _bridgeClassName = "org.apache.kafka.common.replica.RackAwareReplicaSelector"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public RackAwareReplicaSelector() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public RackAwareReplicaSelector(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 ReplicaSelector - /// - /// - /// - public partial class ReplicaSelector : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.replica.ReplicaSelector"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("ReplicaSelector 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 ReplicaSelector() { } - /// - /// 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("ReplicaSelector 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 ReplicaSelector(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 ReplicaView - /// - /// - /// - public partial class ReplicaView : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.replica.ReplicaView"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("ReplicaView 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 ReplicaView() { } - /// - /// 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("ReplicaView 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 ReplicaView(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 - #region DefaultReplicaView - /// - /// - /// - public partial class DefaultReplicaView : Org.Apache.Kafka.Common.Replica.ReplicaView - { - const string _bridgeClassName = "org.apache.kafka.common.replica.ReplicaView$DefaultReplicaView"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public DefaultReplicaView() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public DefaultReplicaView(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 - - - -} \ No newline at end of file diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Replica/ClientMetadata.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Replica/ClientMetadata.cs index 3ee34a5e5..bff978ba2 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Replica/ClientMetadata.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Replica/ClientMetadata.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,98 @@ namespace Org.Apache.Kafka.Common.Replica { + #region ClientMetadata declaration + /// + /// + /// + public partial class ClientMetadata : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.replica.ClientMetadata"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("ClientMetadata 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 ClientMetadata() { } + /// + /// 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("ClientMetadata 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 ClientMetadata(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 + #region DefaultClientMetadata declaration + /// + /// + /// + public partial class DefaultClientMetadata : Org.Apache.Kafka.Common.Replica.ClientMetadata + { + const string _bridgeClassName = "org.apache.kafka.common.replica.ClientMetadata$DefaultClientMetadata"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public DefaultClientMetadata() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public DefaultClientMetadata(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 IClientMetadata /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +135,7 @@ public partial interface IClientMetadata } #endregion - #region ClientMetadata + #region ClientMetadata implementation public partial class ClientMetadata : Org.Apache.Kafka.Common.Replica.IClientMetadata { #region Constructors @@ -107,7 +199,7 @@ public Org.Apache.Kafka.Common.Security.Auth.KafkaPrincipal Principal() #endregion #region Nested classes - #region DefaultClientMetadata + #region DefaultClientMetadata implementation public partial class DefaultClientMetadata { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Replica/PartitionView.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Replica/PartitionView.cs index 1aaf92217..aba2bcad4 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Replica/PartitionView.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Replica/PartitionView.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,98 @@ namespace Org.Apache.Kafka.Common.Replica { + #region PartitionView declaration + /// + /// + /// + public partial class PartitionView : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.replica.PartitionView"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("PartitionView 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 PartitionView() { } + /// + /// 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("PartitionView 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 PartitionView(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 + #region DefaultPartitionView declaration + /// + /// + /// + public partial class DefaultPartitionView : Org.Apache.Kafka.Common.Replica.PartitionView + { + const string _bridgeClassName = "org.apache.kafka.common.replica.PartitionView$DefaultPartitionView"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public DefaultPartitionView() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public DefaultPartitionView(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 IPartitionView /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +135,7 @@ public partial interface IPartitionView } #endregion - #region PartitionView + #region PartitionView implementation public partial class PartitionView : Org.Apache.Kafka.Common.Replica.IPartitionView { #region Constructors @@ -83,7 +175,7 @@ public Org.Apache.Kafka.Common.Replica.ReplicaView Leader() #endregion #region Nested classes - #region DefaultPartitionView + #region DefaultPartitionView implementation public partial class DefaultPartitionView { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Replica/RackAwareReplicaSelector.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Replica/RackAwareReplicaSelector.cs index 614fac61a..ca353ae85 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Replica/RackAwareReplicaSelector.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Replica/RackAwareReplicaSelector.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.Common.Replica { - #region RackAwareReplicaSelector + #region RackAwareReplicaSelector declaration + /// + /// + /// + public partial class RackAwareReplicaSelector : Org.Apache.Kafka.Common.Replica.ReplicaSelector + { + const string _bridgeClassName = "org.apache.kafka.common.replica.RackAwareReplicaSelector"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public RackAwareReplicaSelector() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public RackAwareReplicaSelector(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 RackAwareReplicaSelector implementation public partial class RackAwareReplicaSelector { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Replica/ReplicaSelector.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Replica/ReplicaSelector.cs index aba156422..b64fca447 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Replica/ReplicaSelector.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Replica/ReplicaSelector.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.Common.Replica { + #region ReplicaSelector declaration + /// + /// + /// + public partial class ReplicaSelector : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.replica.ReplicaSelector"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("ReplicaSelector 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 ReplicaSelector() { } + /// + /// 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("ReplicaSelector 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 ReplicaSelector(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 IReplicaSelector /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +90,7 @@ public partial interface IReplicaSelector } #endregion - #region ReplicaSelector + #region ReplicaSelector implementation public partial class ReplicaSelector : Org.Apache.Kafka.Common.Replica.IReplicaSelector, Org.Apache.Kafka.Common.IConfigurable, Java.Io.ICloseable { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Replica/ReplicaView.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Replica/ReplicaView.cs index 1c8a21f35..627137653 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Replica/ReplicaView.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Replica/ReplicaView.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,98 @@ namespace Org.Apache.Kafka.Common.Replica { + #region ReplicaView declaration + /// + /// + /// + public partial class ReplicaView : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.replica.ReplicaView"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("ReplicaView 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 ReplicaView() { } + /// + /// 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("ReplicaView 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 ReplicaView(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 + #region DefaultReplicaView declaration + /// + /// + /// + public partial class DefaultReplicaView : Org.Apache.Kafka.Common.Replica.ReplicaView + { + const string _bridgeClassName = "org.apache.kafka.common.replica.ReplicaView$DefaultReplicaView"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public DefaultReplicaView() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public DefaultReplicaView(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 IReplicaView /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +135,7 @@ public partial interface IReplicaView } #endregion - #region ReplicaView + #region ReplicaView implementation public partial class ReplicaView : Org.Apache.Kafka.Common.Replica.IReplicaView { #region Constructors @@ -99,7 +191,7 @@ public Org.Apache.Kafka.Common.Node Endpoint() #endregion #region Nested classes - #region DefaultReplicaView + #region DefaultReplicaView implementation public partial class DefaultReplicaView { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Resource/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Resource/AllPackageClasses.cs deleted file mode 100644 index 831f6c1a7..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Resource/AllPackageClasses.cs +++ /dev/null @@ -1,256 +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.Common.Resource -{ - #region PatternType - /// - /// - /// - public partial class PatternType : Java.Lang.Enum - { - const string _bridgeClassName = "org.apache.kafka.common.resource.PatternType"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public PatternType() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public PatternType(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 Resource - /// - /// - /// - public partial class Resource : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.resource.Resource"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Resource() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Resource(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 ResourcePattern - /// - /// - /// - public partial class ResourcePattern : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.resource.ResourcePattern"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ResourcePattern() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ResourcePattern(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 ResourcePatternFilter - /// - /// - /// - public partial class ResourcePatternFilter : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.resource.ResourcePatternFilter"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ResourcePatternFilter() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ResourcePatternFilter(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 ResourceType - /// - /// - /// - public partial class ResourceType : Java.Lang.Enum - { - const string _bridgeClassName = "org.apache.kafka.common.resource.ResourceType"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ResourceType() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ResourceType(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/Common/Resource/PatternType.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Resource/PatternType.cs index 4e938e31a..a37ebcee4 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Resource/PatternType.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Resource/PatternType.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.Common.Resource { - #region PatternType + #region PatternType declaration + /// + /// + /// + public partial class PatternType : Java.Lang.Enum + { + const string _bridgeClassName = "org.apache.kafka.common.resource.PatternType"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public PatternType() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public PatternType(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 PatternType implementation public partial class PatternType { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Resource/Resource.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Resource/Resource.cs index 83f551f35..d4718cf81 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Resource/Resource.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Resource/Resource.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.Common.Resource { - #region Resource + #region Resource declaration + /// + /// + /// + public partial class Resource : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.resource.Resource"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Resource() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Resource(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 Resource implementation public partial class Resource { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Resource/ResourcePattern.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Resource/ResourcePattern.cs index c3908e2f4..84608b730 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Resource/ResourcePattern.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Resource/ResourcePattern.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.Common.Resource { - #region ResourcePattern + #region ResourcePattern declaration + /// + /// + /// + public partial class ResourcePattern : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.resource.ResourcePattern"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ResourcePattern() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ResourcePattern(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 ResourcePattern implementation public partial class ResourcePattern { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Resource/ResourcePatternFilter.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Resource/ResourcePatternFilter.cs index a1d8ac7b3..a33fbb50a 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Resource/ResourcePatternFilter.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Resource/ResourcePatternFilter.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.Common.Resource { - #region ResourcePatternFilter + #region ResourcePatternFilter declaration + /// + /// + /// + public partial class ResourcePatternFilter : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.resource.ResourcePatternFilter"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ResourcePatternFilter() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ResourcePatternFilter(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 ResourcePatternFilter implementation public partial class ResourcePatternFilter { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Resource/ResourceType.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Resource/ResourceType.cs index 240cedce7..1c5ace0cc 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Resource/ResourceType.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Resource/ResourceType.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.Common.Resource { - #region ResourceType + #region ResourceType declaration + /// + /// + /// + public partial class ResourceType : Java.Lang.Enum + { + const string _bridgeClassName = "org.apache.kafka.common.resource.ResourceType"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ResourceType() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ResourceType(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 ResourceType implementation public partial class ResourceType { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/AllPackageClasses.cs deleted file mode 100644 index cca8f2d38..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/AllPackageClasses.cs +++ /dev/null @@ -1,166 +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.Common.Security -{ - #region JaasContext - /// - /// - /// - public partial class JaasContext : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.security.JaasContext"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public JaasContext() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public JaasContext(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 Type - /// - /// - /// - public partial class Type : Java.Lang.Enum - { - const string _bridgeClassName = "org.apache.kafka.common.security.JaasContext$Type"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Type() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Type(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 JaasUtils - /// - /// - /// - public partial class JaasUtils : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.security.JaasUtils"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public JaasUtils() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public JaasUtils(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/Common/Security/Auth/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/AllPackageClasses.cs deleted file mode 100644 index 09102c27a..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/AllPackageClasses.cs +++ /dev/null @@ -1,675 +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.Common.Security.Auth -{ - #region AuthenticateCallbackHandler - /// - /// - /// - public partial class AuthenticateCallbackHandler : Javax.Security.Auth.Callback.CallbackHandler - { - const string _bridgeClassName = "org.apache.kafka.common.security.auth.AuthenticateCallbackHandler"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("AuthenticateCallbackHandler 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 AuthenticateCallbackHandler() { } - /// - /// 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("AuthenticateCallbackHandler 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 AuthenticateCallbackHandler(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 AuthenticationContext - /// - /// - /// - public partial class AuthenticationContext : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.security.auth.AuthenticationContext"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("AuthenticationContext 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 AuthenticationContext() { } - /// - /// 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("AuthenticationContext 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 AuthenticationContext(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 KafkaPrincipal - /// - /// - /// - public partial class KafkaPrincipal : Java.Security.Principal - { - const string _bridgeClassName = "org.apache.kafka.common.security.auth.KafkaPrincipal"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public KafkaPrincipal() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public KafkaPrincipal(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 KafkaPrincipalBuilder - /// - /// - /// - public partial class KafkaPrincipalBuilder : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.security.auth.KafkaPrincipalBuilder"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("KafkaPrincipalBuilder 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 KafkaPrincipalBuilder() { } - /// - /// 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("KafkaPrincipalBuilder 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 KafkaPrincipalBuilder(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 KafkaPrincipalSerde - /// - /// - /// - public partial class KafkaPrincipalSerde : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.security.auth.KafkaPrincipalSerde"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("KafkaPrincipalSerde 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 KafkaPrincipalSerde() { } - /// - /// 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("KafkaPrincipalSerde 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 KafkaPrincipalSerde(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 Login - /// - /// - /// - public partial class Login : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.security.auth.Login"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("Login 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 Login() { } - /// - /// 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("Login 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 Login(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 PlaintextAuthenticationContext - /// - /// - /// - public partial class PlaintextAuthenticationContext : Org.Apache.Kafka.Common.Security.Auth.AuthenticationContext - { - const string _bridgeClassName = "org.apache.kafka.common.security.auth.PlaintextAuthenticationContext"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public PlaintextAuthenticationContext() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public PlaintextAuthenticationContext(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 SaslAuthenticationContext - /// - /// - /// - public partial class SaslAuthenticationContext : Org.Apache.Kafka.Common.Security.Auth.AuthenticationContext - { - const string _bridgeClassName = "org.apache.kafka.common.security.auth.SaslAuthenticationContext"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public SaslAuthenticationContext() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public SaslAuthenticationContext(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 SaslExtensions - /// - /// - /// - public partial class SaslExtensions : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.security.auth.SaslExtensions"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public SaslExtensions() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public SaslExtensions(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 SaslExtensionsCallback - /// - /// - /// - public partial class SaslExtensionsCallback : Javax.Security.Auth.Callback.Callback - { - const string _bridgeClassName = "org.apache.kafka.common.security.auth.SaslExtensionsCallback"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public SaslExtensionsCallback() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public SaslExtensionsCallback(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 SecurityProtocol - /// - /// - /// - public partial class SecurityProtocol : Java.Lang.Enum - { - const string _bridgeClassName = "org.apache.kafka.common.security.auth.SecurityProtocol"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public SecurityProtocol() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public SecurityProtocol(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 SecurityProviderCreator - /// - /// - /// - public partial class SecurityProviderCreator : Org.Apache.Kafka.Common.Configurable - { - const string _bridgeClassName = "org.apache.kafka.common.security.auth.SecurityProviderCreator"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("SecurityProviderCreator 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 SecurityProviderCreator() { } - /// - /// 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("SecurityProviderCreator 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 SecurityProviderCreator(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 SslAuthenticationContext - /// - /// - /// - public partial class SslAuthenticationContext : Org.Apache.Kafka.Common.Security.Auth.AuthenticationContext - { - const string _bridgeClassName = "org.apache.kafka.common.security.auth.SslAuthenticationContext"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public SslAuthenticationContext() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public SslAuthenticationContext(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 SslEngineFactory - /// - /// - /// - public partial class SslEngineFactory : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.security.auth.SslEngineFactory"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("SslEngineFactory 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 SslEngineFactory() { } - /// - /// 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("SslEngineFactory 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 SslEngineFactory(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 - - - -} \ No newline at end of file diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/AuthenticateCallbackHandler.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/AuthenticateCallbackHandler.cs index e41338ace..865d5008f 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/AuthenticateCallbackHandler.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/AuthenticateCallbackHandler.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.Common.Security.Auth { + #region AuthenticateCallbackHandler declaration + /// + /// + /// + public partial class AuthenticateCallbackHandler : Javax.Security.Auth.Callback.CallbackHandler + { + const string _bridgeClassName = "org.apache.kafka.common.security.auth.AuthenticateCallbackHandler"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("AuthenticateCallbackHandler 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 AuthenticateCallbackHandler() { } + /// + /// 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("AuthenticateCallbackHandler 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 AuthenticateCallbackHandler(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 IAuthenticateCallbackHandler /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +90,7 @@ public partial interface IAuthenticateCallbackHandler : Javax.Security.Auth.Call } #endregion - #region AuthenticateCallbackHandler + #region AuthenticateCallbackHandler implementation public partial class AuthenticateCallbackHandler : Org.Apache.Kafka.Common.Security.Auth.IAuthenticateCallbackHandler { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/AuthenticationContext.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/AuthenticationContext.cs index 2fad28c68..c4a98f810 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/AuthenticationContext.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/AuthenticationContext.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.Common.Security.Auth { + #region AuthenticationContext declaration + /// + /// + /// + public partial class AuthenticationContext : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.security.auth.AuthenticationContext"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("AuthenticationContext 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 AuthenticationContext() { } + /// + /// 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("AuthenticationContext 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 AuthenticationContext(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 IAuthenticationContext /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +90,7 @@ public partial interface IAuthenticationContext } #endregion - #region AuthenticationContext + #region AuthenticationContext implementation public partial class AuthenticationContext : Org.Apache.Kafka.Common.Security.Auth.IAuthenticationContext { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/KafkaPrincipal.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/KafkaPrincipal.cs index 6c52b5e33..f3d0edb8e 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/KafkaPrincipal.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/KafkaPrincipal.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.Common.Security.Auth { - #region KafkaPrincipal + #region KafkaPrincipal declaration + /// + /// + /// + public partial class KafkaPrincipal : Java.Security.Principal + { + const string _bridgeClassName = "org.apache.kafka.common.security.auth.KafkaPrincipal"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public KafkaPrincipal() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public KafkaPrincipal(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 KafkaPrincipal implementation public partial class KafkaPrincipal { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/KafkaPrincipalBuilder.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/KafkaPrincipalBuilder.cs index a901904ab..bd1122a9b 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/KafkaPrincipalBuilder.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/KafkaPrincipalBuilder.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.Common.Security.Auth { + #region KafkaPrincipalBuilder declaration + /// + /// + /// + public partial class KafkaPrincipalBuilder : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.security.auth.KafkaPrincipalBuilder"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("KafkaPrincipalBuilder 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 KafkaPrincipalBuilder() { } + /// + /// 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("KafkaPrincipalBuilder 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 KafkaPrincipalBuilder(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 IKafkaPrincipalBuilder /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +90,7 @@ public partial interface IKafkaPrincipalBuilder } #endregion - #region KafkaPrincipalBuilder + #region KafkaPrincipalBuilder implementation public partial class KafkaPrincipalBuilder : Org.Apache.Kafka.Common.Security.Auth.IKafkaPrincipalBuilder { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/KafkaPrincipalSerde.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/KafkaPrincipalSerde.cs index 931e65bfc..d767b6200 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/KafkaPrincipalSerde.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/KafkaPrincipalSerde.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.Common.Security.Auth { + #region KafkaPrincipalSerde declaration + /// + /// + /// + public partial class KafkaPrincipalSerde : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.security.auth.KafkaPrincipalSerde"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("KafkaPrincipalSerde 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 KafkaPrincipalSerde() { } + /// + /// 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("KafkaPrincipalSerde 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 KafkaPrincipalSerde(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 IKafkaPrincipalSerde /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +90,7 @@ public partial interface IKafkaPrincipalSerde } #endregion - #region KafkaPrincipalSerde + #region KafkaPrincipalSerde implementation public partial class KafkaPrincipalSerde : Org.Apache.Kafka.Common.Security.Auth.IKafkaPrincipalSerde { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/Login.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/Login.cs index df4ddc1e9..34050598a 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/Login.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/Login.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.Common.Security.Auth { + #region Login declaration + /// + /// + /// + public partial class Login : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.security.auth.Login"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("Login 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 Login() { } + /// + /// 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("Login 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 Login(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 ILogin /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +90,7 @@ public partial interface ILogin } #endregion - #region Login + #region Login implementation public partial class Login : Org.Apache.Kafka.Common.Security.Auth.ILogin { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/PlaintextAuthenticationContext.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/PlaintextAuthenticationContext.cs index 44425603b..f0fd091cd 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/PlaintextAuthenticationContext.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/PlaintextAuthenticationContext.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.Common.Security.Auth { - #region PlaintextAuthenticationContext + #region PlaintextAuthenticationContext declaration + /// + /// + /// + public partial class PlaintextAuthenticationContext : Org.Apache.Kafka.Common.Security.Auth.AuthenticationContext + { + const string _bridgeClassName = "org.apache.kafka.common.security.auth.PlaintextAuthenticationContext"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public PlaintextAuthenticationContext() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public PlaintextAuthenticationContext(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 PlaintextAuthenticationContext implementation public partial class PlaintextAuthenticationContext { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/SaslAuthenticationContext.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/SaslAuthenticationContext.cs index 6f484aabb..d92caecc0 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/SaslAuthenticationContext.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/SaslAuthenticationContext.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.Common.Security.Auth { - #region SaslAuthenticationContext + #region SaslAuthenticationContext declaration + /// + /// + /// + public partial class SaslAuthenticationContext : Org.Apache.Kafka.Common.Security.Auth.AuthenticationContext + { + const string _bridgeClassName = "org.apache.kafka.common.security.auth.SaslAuthenticationContext"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public SaslAuthenticationContext() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public SaslAuthenticationContext(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 SaslAuthenticationContext implementation public partial class SaslAuthenticationContext { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/SaslExtensions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/SaslExtensions.cs index a836b196e..73946410e 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/SaslExtensions.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/SaslExtensions.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.Common.Security.Auth { - #region SaslExtensions + #region SaslExtensions declaration + /// + /// + /// + public partial class SaslExtensions : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.security.auth.SaslExtensions"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public SaslExtensions() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public SaslExtensions(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 SaslExtensions implementation public partial class SaslExtensions { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/SaslExtensionsCallback.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/SaslExtensionsCallback.cs index ea079de8d..12e79c831 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/SaslExtensionsCallback.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/SaslExtensionsCallback.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.Common.Security.Auth { - #region SaslExtensionsCallback + #region SaslExtensionsCallback declaration + /// + /// + /// + public partial class SaslExtensionsCallback : Javax.Security.Auth.Callback.Callback + { + const string _bridgeClassName = "org.apache.kafka.common.security.auth.SaslExtensionsCallback"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public SaslExtensionsCallback() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public SaslExtensionsCallback(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 SaslExtensionsCallback implementation public partial class SaslExtensionsCallback { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/SecurityProtocol.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/SecurityProtocol.cs index 7d2ce18da..b2157876c 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/SecurityProtocol.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/SecurityProtocol.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.Common.Security.Auth { - #region SecurityProtocol + #region SecurityProtocol declaration + /// + /// + /// + public partial class SecurityProtocol : Java.Lang.Enum + { + const string _bridgeClassName = "org.apache.kafka.common.security.auth.SecurityProtocol"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public SecurityProtocol() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public SecurityProtocol(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 SecurityProtocol implementation public partial class SecurityProtocol { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/SecurityProviderCreator.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/SecurityProviderCreator.cs index 92a7424d5..4811671c5 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/SecurityProviderCreator.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/SecurityProviderCreator.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.Common.Security.Auth { + #region SecurityProviderCreator declaration + /// + /// + /// + public partial class SecurityProviderCreator : Org.Apache.Kafka.Common.Configurable + { + const string _bridgeClassName = "org.apache.kafka.common.security.auth.SecurityProviderCreator"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("SecurityProviderCreator 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 SecurityProviderCreator() { } + /// + /// 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("SecurityProviderCreator 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 SecurityProviderCreator(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 ISecurityProviderCreator /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +90,7 @@ public partial interface ISecurityProviderCreator : Org.Apache.Kafka.Common.ICon } #endregion - #region SecurityProviderCreator + #region SecurityProviderCreator implementation public partial class SecurityProviderCreator : Org.Apache.Kafka.Common.Security.Auth.ISecurityProviderCreator { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/SslAuthenticationContext.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/SslAuthenticationContext.cs index 95de9a6db..4f08ed6e0 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/SslAuthenticationContext.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/SslAuthenticationContext.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.Common.Security.Auth { - #region SslAuthenticationContext + #region SslAuthenticationContext declaration + /// + /// + /// + public partial class SslAuthenticationContext : Org.Apache.Kafka.Common.Security.Auth.AuthenticationContext + { + const string _bridgeClassName = "org.apache.kafka.common.security.auth.SslAuthenticationContext"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public SslAuthenticationContext() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public SslAuthenticationContext(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 SslAuthenticationContext implementation public partial class SslAuthenticationContext { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/SslEngineFactory.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/SslEngineFactory.cs index 7305a69c4..b33948271 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/SslEngineFactory.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/SslEngineFactory.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.Common.Security.Auth { + #region SslEngineFactory declaration + /// + /// + /// + public partial class SslEngineFactory : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.security.auth.SslEngineFactory"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("SslEngineFactory 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 SslEngineFactory() { } + /// + /// 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("SslEngineFactory 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 SslEngineFactory(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 ISslEngineFactory /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +90,7 @@ public partial interface ISslEngineFactory } #endregion - #region SslEngineFactory + #region SslEngineFactory implementation public partial class SslEngineFactory : Org.Apache.Kafka.Common.Security.Auth.ISslEngineFactory, Org.Apache.Kafka.Common.IConfigurable, Java.Io.ICloseable { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/AbstractLogin.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/AbstractLogin.cs index d305af956..2db4207bd 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/AbstractLogin.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/AbstractLogin.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,99 @@ namespace Org.Apache.Kafka.Common.Security.Authenticator { - #region AbstractLogin + #region AbstractLogin declaration + /// + /// + /// + public partial class AbstractLogin : Org.Apache.Kafka.Common.Security.Auth.Login + { + const string _bridgeClassName = "org.apache.kafka.common.security.authenticator.AbstractLogin"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("AbstractLogin 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 AbstractLogin() { } + /// + /// 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("AbstractLogin 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 AbstractLogin(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 + #region DefaultLoginCallbackHandler declaration + /// + /// + /// + public partial class DefaultLoginCallbackHandler : Org.Apache.Kafka.Common.Security.Auth.AuthenticateCallbackHandler + { + const string _bridgeClassName = "org.apache.kafka.common.security.authenticator.AbstractLogin$DefaultLoginCallbackHandler"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public DefaultLoginCallbackHandler() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public DefaultLoginCallbackHandler(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 AbstractLogin implementation public partial class AbstractLogin { #region Constructors @@ -77,7 +169,7 @@ public void Configure(Java.Util.Map arg0, Java.Lang.St #endregion #region Nested classes - #region DefaultLoginCallbackHandler + #region DefaultLoginCallbackHandler implementation public partial class DefaultLoginCallbackHandler { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/AllPackageClasses.cs deleted file mode 100644 index f1d5fe999..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/AllPackageClasses.cs +++ /dev/null @@ -1,664 +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.Common.Security.Authenticator -{ - #region AbstractLogin - /// - /// - /// - public partial class AbstractLogin : Org.Apache.Kafka.Common.Security.Auth.Login - { - const string _bridgeClassName = "org.apache.kafka.common.security.authenticator.AbstractLogin"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("AbstractLogin 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 AbstractLogin() { } - /// - /// 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("AbstractLogin 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 AbstractLogin(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 - #region DefaultLoginCallbackHandler - /// - /// - /// - public partial class DefaultLoginCallbackHandler : Org.Apache.Kafka.Common.Security.Auth.AuthenticateCallbackHandler - { - const string _bridgeClassName = "org.apache.kafka.common.security.authenticator.AbstractLogin$DefaultLoginCallbackHandler"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public DefaultLoginCallbackHandler() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public DefaultLoginCallbackHandler(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 CredentialCache - /// - /// - /// - public partial class CredentialCache : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.security.authenticator.CredentialCache"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public CredentialCache() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public CredentialCache(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 Cache - /// - /// - /// - public partial class Cache : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.security.authenticator.CredentialCache$Cache"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Cache() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Cache(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 Cache - /// - /// - /// - /// - public partial class Cache : MASES.JCOBridge.C2JBridge.JVMBridgeBase> - { - const string _bridgeClassName = "org.apache.kafka.common.security.authenticator.CredentialCache$Cache"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Cache() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Cache(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 DefaultKafkaPrincipalBuilder - /// - /// - /// - public partial class DefaultKafkaPrincipalBuilder : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.security.authenticator.DefaultKafkaPrincipalBuilder"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public DefaultKafkaPrincipalBuilder() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public DefaultKafkaPrincipalBuilder(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 DefaultLogin - /// - /// - /// - public partial class DefaultLogin : Org.Apache.Kafka.Common.Security.Authenticator.AbstractLogin - { - const string _bridgeClassName = "org.apache.kafka.common.security.authenticator.DefaultLogin"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public DefaultLogin() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public DefaultLogin(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 LoginManager - /// - /// - /// - public partial class LoginManager : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.security.authenticator.LoginManager"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public LoginManager() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public LoginManager(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 SaslClientAuthenticator - /// - /// - /// - public partial class SaslClientAuthenticator : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.security.authenticator.SaslClientAuthenticator"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public SaslClientAuthenticator() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public SaslClientAuthenticator(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 SaslState - /// - /// - /// - public partial class SaslState : Java.Lang.Enum - { - const string _bridgeClassName = "org.apache.kafka.common.security.authenticator.SaslClientAuthenticator$SaslState"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public SaslState() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public SaslState(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 SaslClientCallbackHandler - /// - /// - /// - public partial class SaslClientCallbackHandler : Org.Apache.Kafka.Common.Security.Auth.AuthenticateCallbackHandler - { - const string _bridgeClassName = "org.apache.kafka.common.security.authenticator.SaslClientCallbackHandler"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public SaslClientCallbackHandler() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public SaslClientCallbackHandler(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 SaslInternalConfigs - /// - /// - /// - public partial class SaslInternalConfigs : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.security.authenticator.SaslInternalConfigs"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public SaslInternalConfigs() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public SaslInternalConfigs(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 SaslServerAuthenticator - /// - /// - /// - public partial class SaslServerAuthenticator : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.security.authenticator.SaslServerAuthenticator"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public SaslServerAuthenticator() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public SaslServerAuthenticator(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 SaslServerCallbackHandler - /// - /// - /// - public partial class SaslServerCallbackHandler : Org.Apache.Kafka.Common.Security.Auth.AuthenticateCallbackHandler - { - const string _bridgeClassName = "org.apache.kafka.common.security.authenticator.SaslServerCallbackHandler"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public SaslServerCallbackHandler() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public SaslServerCallbackHandler(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/Common/Security/Authenticator/CredentialCache.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/CredentialCache.cs index 899f4a276..409899ccb 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/CredentialCache.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/CredentialCache.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,143 @@ namespace Org.Apache.Kafka.Common.Security.Authenticator { - #region CredentialCache + #region CredentialCache declaration + /// + /// + /// + public partial class CredentialCache : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.security.authenticator.CredentialCache"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public CredentialCache() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public CredentialCache(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 Cache declaration + /// + /// + /// + public partial class Cache : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.security.authenticator.CredentialCache$Cache"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Cache() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Cache(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 Cache declaration + /// + /// + /// + /// + public partial class Cache : MASES.JCOBridge.C2JBridge.JVMBridgeBase> + { + const string _bridgeClassName = "org.apache.kafka.common.security.authenticator.CredentialCache$Cache"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Cache() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Cache(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 CredentialCache implementation public partial class CredentialCache { #region Constructors @@ -71,7 +207,7 @@ public Org.Apache.Kafka.Common.Security.Authenticator.CredentialCache.Cache C #endregion #region Nested classes - #region Cache + #region Cache implementation public partial class Cache { #region Constructors @@ -146,7 +282,7 @@ public Java.Lang.Class CredentialClass() } #endregion - #region Cache + #region Cache implementation public partial class Cache { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/DefaultKafkaPrincipalBuilder.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/DefaultKafkaPrincipalBuilder.cs index a4ab0b1d6..4014eae11 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/DefaultKafkaPrincipalBuilder.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/DefaultKafkaPrincipalBuilder.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.Common.Security.Authenticator { - #region DefaultKafkaPrincipalBuilder + #region DefaultKafkaPrincipalBuilder declaration + /// + /// + /// + public partial class DefaultKafkaPrincipalBuilder : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.security.authenticator.DefaultKafkaPrincipalBuilder"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public DefaultKafkaPrincipalBuilder() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public DefaultKafkaPrincipalBuilder(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 DefaultKafkaPrincipalBuilder implementation public partial class DefaultKafkaPrincipalBuilder : Org.Apache.Kafka.Common.Security.Auth.IKafkaPrincipalBuilder, Org.Apache.Kafka.Common.Security.Auth.IKafkaPrincipalSerde { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/DefaultLogin.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/DefaultLogin.cs index 441284920..8d38ca377 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/DefaultLogin.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/DefaultLogin.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.Common.Security.Authenticator { - #region DefaultLogin + #region DefaultLogin declaration + /// + /// + /// + public partial class DefaultLogin : Org.Apache.Kafka.Common.Security.Authenticator.AbstractLogin + { + const string _bridgeClassName = "org.apache.kafka.common.security.authenticator.DefaultLogin"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public DefaultLogin() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public DefaultLogin(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 DefaultLogin implementation public partial class DefaultLogin { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/LoginManager.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/LoginManager.cs index cec2eb4e3..2354bc230 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/LoginManager.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/LoginManager.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.Common.Security.Authenticator { - #region LoginManager + #region LoginManager declaration + /// + /// + /// + public partial class LoginManager : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.security.authenticator.LoginManager"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public LoginManager() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public LoginManager(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 LoginManager implementation public partial class LoginManager { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/SaslClientAuthenticator.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/SaslClientAuthenticator.cs index 399294273..17439d028 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/SaslClientAuthenticator.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/SaslClientAuthenticator.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.Common.Security.Authenticator { - #region SaslClientAuthenticator + #region SaslClientAuthenticator declaration + /// + /// + /// + public partial class SaslClientAuthenticator : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.security.authenticator.SaslClientAuthenticator"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public SaslClientAuthenticator() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public SaslClientAuthenticator(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 SaslState declaration + /// + /// + /// + public partial class SaslState : Java.Lang.Enum + { + const string _bridgeClassName = "org.apache.kafka.common.security.authenticator.SaslClientAuthenticator$SaslState"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public SaslState() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public SaslState(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 SaslClientAuthenticator implementation public partial class SaslClientAuthenticator { #region Constructors @@ -135,7 +225,7 @@ public void Close() #endregion #region Nested classes - #region SaslState + #region SaslState implementation public partial class SaslState { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/SaslClientCallbackHandler.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/SaslClientCallbackHandler.cs index a74308047..bcc2c3535 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/SaslClientCallbackHandler.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/SaslClientCallbackHandler.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.Common.Security.Authenticator { - #region SaslClientCallbackHandler + #region SaslClientCallbackHandler declaration + /// + /// + /// + public partial class SaslClientCallbackHandler : Org.Apache.Kafka.Common.Security.Auth.AuthenticateCallbackHandler + { + const string _bridgeClassName = "org.apache.kafka.common.security.authenticator.SaslClientCallbackHandler"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public SaslClientCallbackHandler() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public SaslClientCallbackHandler(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 SaslClientCallbackHandler implementation public partial class SaslClientCallbackHandler { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/SaslInternalConfigs.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/SaslInternalConfigs.cs index 3166a4940..a579d8942 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/SaslInternalConfigs.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/SaslInternalConfigs.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.Common.Security.Authenticator { - #region SaslInternalConfigs + #region SaslInternalConfigs declaration + /// + /// + /// + public partial class SaslInternalConfigs : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.security.authenticator.SaslInternalConfigs"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public SaslInternalConfigs() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public SaslInternalConfigs(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 SaslInternalConfigs implementation public partial class SaslInternalConfigs { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/SaslServerAuthenticator.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/SaslServerAuthenticator.cs index 17a3e25dd..a60a85cf8 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/SaslServerAuthenticator.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/SaslServerAuthenticator.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.Common.Security.Authenticator { - #region SaslServerAuthenticator + #region SaslServerAuthenticator declaration + /// + /// + /// + public partial class SaslServerAuthenticator : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.security.authenticator.SaslServerAuthenticator"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public SaslServerAuthenticator() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public SaslServerAuthenticator(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 SaslServerAuthenticator implementation public partial class SaslServerAuthenticator { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/SaslServerCallbackHandler.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/SaslServerCallbackHandler.cs index 3ebf4abe8..edb507201 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/SaslServerCallbackHandler.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/SaslServerCallbackHandler.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.Common.Security.Authenticator { - #region SaslServerCallbackHandler + #region SaslServerCallbackHandler declaration + /// + /// + /// + public partial class SaslServerCallbackHandler : Org.Apache.Kafka.Common.Security.Auth.AuthenticateCallbackHandler + { + const string _bridgeClassName = "org.apache.kafka.common.security.authenticator.SaslServerCallbackHandler"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public SaslServerCallbackHandler() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public SaslServerCallbackHandler(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 SaslServerCallbackHandler implementation public partial class SaslServerCallbackHandler { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/JaasContext.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/JaasContext.cs index 89c5ccc8a..ff025e639 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/JaasContext.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/JaasContext.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.Common.Security { - #region JaasContext + #region JaasContext declaration + /// + /// + /// + public partial class JaasContext : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.security.JaasContext"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public JaasContext() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public JaasContext(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 Type declaration + /// + /// + /// + public partial class Type : Java.Lang.Enum + { + const string _bridgeClassName = "org.apache.kafka.common.security.JaasContext$Type"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Type() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Type(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 JaasContext implementation public partial class JaasContext { #region Constructors @@ -120,7 +210,7 @@ public Org.Apache.Kafka.Common.Security.JaasContext.Type TypeMethod() #endregion #region Nested classes - #region Type + #region Type implementation public partial class Type { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/JaasUtils.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/JaasUtils.cs index b1c34ebf2..425b11835 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/JaasUtils.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/JaasUtils.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.Common.Security { - #region JaasUtils + #region JaasUtils declaration + /// + /// + /// + public partial class JaasUtils : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.security.JaasUtils"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public JaasUtils() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public JaasUtils(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 JaasUtils implementation public partial class JaasUtils { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/AllPackageClasses.cs deleted file mode 100644 index accf9f84e..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/AllPackageClasses.cs +++ /dev/null @@ -1,348 +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.Common.Security.Oauthbearer -{ - #region OAuthBearerExtensionsValidatorCallback - /// - /// - /// - public partial class OAuthBearerExtensionsValidatorCallback : Javax.Security.Auth.Callback.Callback - { - const string _bridgeClassName = "org.apache.kafka.common.security.oauthbearer.OAuthBearerExtensionsValidatorCallback"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public OAuthBearerExtensionsValidatorCallback() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public OAuthBearerExtensionsValidatorCallback(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 OAuthBearerLoginCallbackHandler - /// - /// - /// - public partial class OAuthBearerLoginCallbackHandler : Org.Apache.Kafka.Common.Security.Auth.AuthenticateCallbackHandler - { - const string _bridgeClassName = "org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginCallbackHandler"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public OAuthBearerLoginCallbackHandler() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public OAuthBearerLoginCallbackHandler(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 OAuthBearerLoginModule - /// - /// - /// - public partial class OAuthBearerLoginModule : Javax.Security.Auth.Spi.LoginModule - { - const string _bridgeClassName = "org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginModule"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public OAuthBearerLoginModule() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public OAuthBearerLoginModule(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 OAuthBearerToken - /// - /// - /// - public partial class OAuthBearerToken : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.security.oauthbearer.OAuthBearerToken"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("OAuthBearerToken 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 OAuthBearerToken() { } - /// - /// 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("OAuthBearerToken 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 OAuthBearerToken(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 OAuthBearerTokenCallback - /// - /// - /// - public partial class OAuthBearerTokenCallback : Javax.Security.Auth.Callback.Callback - { - const string _bridgeClassName = "org.apache.kafka.common.security.oauthbearer.OAuthBearerTokenCallback"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public OAuthBearerTokenCallback() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public OAuthBearerTokenCallback(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 OAuthBearerValidatorCallback - /// - /// - /// - public partial class OAuthBearerValidatorCallback : Javax.Security.Auth.Callback.Callback - { - const string _bridgeClassName = "org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallback"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public OAuthBearerValidatorCallback() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public OAuthBearerValidatorCallback(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 OAuthBearerValidatorCallbackHandler - /// - /// - /// - public partial class OAuthBearerValidatorCallbackHandler : Org.Apache.Kafka.Common.Security.Auth.AuthenticateCallbackHandler - { - const string _bridgeClassName = "org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallbackHandler"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public OAuthBearerValidatorCallbackHandler() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public OAuthBearerValidatorCallbackHandler(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/Common/Security/Oauthbearer/OAuthBearerExtensionsValidatorCallback.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/OAuthBearerExtensionsValidatorCallback.cs index 4a2f5134c..51bf1370b 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/OAuthBearerExtensionsValidatorCallback.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/OAuthBearerExtensionsValidatorCallback.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.Common.Security.Oauthbearer { - #region OAuthBearerExtensionsValidatorCallback + #region OAuthBearerExtensionsValidatorCallback declaration + /// + /// + /// + public partial class OAuthBearerExtensionsValidatorCallback : Javax.Security.Auth.Callback.Callback + { + const string _bridgeClassName = "org.apache.kafka.common.security.oauthbearer.OAuthBearerExtensionsValidatorCallback"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public OAuthBearerExtensionsValidatorCallback() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public OAuthBearerExtensionsValidatorCallback(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 OAuthBearerExtensionsValidatorCallback implementation public partial class OAuthBearerExtensionsValidatorCallback { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/OAuthBearerLoginCallbackHandler.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/OAuthBearerLoginCallbackHandler.cs index f701dc631..00602775d 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/OAuthBearerLoginCallbackHandler.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/OAuthBearerLoginCallbackHandler.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.Common.Security.Oauthbearer { - #region OAuthBearerLoginCallbackHandler + #region OAuthBearerLoginCallbackHandler declaration + /// + /// + /// + public partial class OAuthBearerLoginCallbackHandler : Org.Apache.Kafka.Common.Security.Auth.AuthenticateCallbackHandler + { + const string _bridgeClassName = "org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginCallbackHandler"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public OAuthBearerLoginCallbackHandler() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public OAuthBearerLoginCallbackHandler(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 OAuthBearerLoginCallbackHandler implementation public partial class OAuthBearerLoginCallbackHandler { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/OAuthBearerLoginModule.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/OAuthBearerLoginModule.cs index 415524614..522796d7b 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/OAuthBearerLoginModule.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/OAuthBearerLoginModule.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.Common.Security.Oauthbearer { - #region OAuthBearerLoginModule + #region OAuthBearerLoginModule declaration + /// + /// + /// + public partial class OAuthBearerLoginModule : Javax.Security.Auth.Spi.LoginModule + { + const string _bridgeClassName = "org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginModule"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public OAuthBearerLoginModule() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public OAuthBearerLoginModule(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 OAuthBearerLoginModule implementation public partial class OAuthBearerLoginModule { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/OAuthBearerToken.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/OAuthBearerToken.cs index e8e02c27d..cbeb6b7a4 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/OAuthBearerToken.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/OAuthBearerToken.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.Common.Security.Oauthbearer { + #region OAuthBearerToken declaration + /// + /// + /// + public partial class OAuthBearerToken : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.security.oauthbearer.OAuthBearerToken"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("OAuthBearerToken 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 OAuthBearerToken() { } + /// + /// 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("OAuthBearerToken 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 OAuthBearerToken(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 IOAuthBearerToken /// /// .NET interface for TO BE DEFINED FROM USER @@ -43,7 +90,7 @@ public partial interface IOAuthBearerToken } #endregion - #region OAuthBearerToken + #region OAuthBearerToken implementation public partial class OAuthBearerToken : Org.Apache.Kafka.Common.Security.Oauthbearer.IOAuthBearerToken { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/OAuthBearerTokenCallback.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/OAuthBearerTokenCallback.cs index ced689fa6..bff56cffc 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/OAuthBearerTokenCallback.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/OAuthBearerTokenCallback.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.Common.Security.Oauthbearer { - #region OAuthBearerTokenCallback + #region OAuthBearerTokenCallback declaration + /// + /// + /// + public partial class OAuthBearerTokenCallback : Javax.Security.Auth.Callback.Callback + { + const string _bridgeClassName = "org.apache.kafka.common.security.oauthbearer.OAuthBearerTokenCallback"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public OAuthBearerTokenCallback() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public OAuthBearerTokenCallback(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 OAuthBearerTokenCallback implementation public partial class OAuthBearerTokenCallback { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/OAuthBearerValidatorCallback.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/OAuthBearerValidatorCallback.cs index bb1e1a13e..2e962b5f6 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/OAuthBearerValidatorCallback.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/OAuthBearerValidatorCallback.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.Common.Security.Oauthbearer { - #region OAuthBearerValidatorCallback + #region OAuthBearerValidatorCallback declaration + /// + /// + /// + public partial class OAuthBearerValidatorCallback : Javax.Security.Auth.Callback.Callback + { + const string _bridgeClassName = "org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallback"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public OAuthBearerValidatorCallback() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public OAuthBearerValidatorCallback(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 OAuthBearerValidatorCallback implementation public partial class OAuthBearerValidatorCallback { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/OAuthBearerValidatorCallbackHandler.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/OAuthBearerValidatorCallbackHandler.cs index 85a5bdf05..561a05df0 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/OAuthBearerValidatorCallbackHandler.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/OAuthBearerValidatorCallbackHandler.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.Common.Security.Oauthbearer { - #region OAuthBearerValidatorCallbackHandler + #region OAuthBearerValidatorCallbackHandler declaration + /// + /// + /// + public partial class OAuthBearerValidatorCallbackHandler : Org.Apache.Kafka.Common.Security.Auth.AuthenticateCallbackHandler + { + const string _bridgeClassName = "org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallbackHandler"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public OAuthBearerValidatorCallbackHandler() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public OAuthBearerValidatorCallbackHandler(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 OAuthBearerValidatorCallbackHandler implementation public partial class OAuthBearerValidatorCallbackHandler { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/Secured/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/Secured/AllPackageClasses.cs deleted file mode 100644 index dd5553195..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/Secured/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-clients-3.6.2.jar as reference -*/ - -using MASES.JCOBridge.C2JBridge.JVMInterop; -using System; - -namespace Org.Apache.Kafka.Common.Security.Oauthbearer.Secured -{ - - -} \ No newline at end of file diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Plain/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Plain/AllPackageClasses.cs deleted file mode 100644 index f2cd2de72..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Plain/AllPackageClasses.cs +++ /dev/null @@ -1,121 +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.Common.Security.Plain -{ - #region PlainAuthenticateCallback - /// - /// - /// - public partial class PlainAuthenticateCallback : Javax.Security.Auth.Callback.Callback - { - const string _bridgeClassName = "org.apache.kafka.common.security.plain.PlainAuthenticateCallback"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public PlainAuthenticateCallback() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public PlainAuthenticateCallback(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 PlainLoginModule - /// - /// - /// - public partial class PlainLoginModule : Javax.Security.Auth.Spi.LoginModule - { - const string _bridgeClassName = "org.apache.kafka.common.security.plain.PlainLoginModule"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public PlainLoginModule() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public PlainLoginModule(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/Common/Security/Plain/Internals/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Plain/Internals/AllPackageClasses.cs deleted file mode 100644 index ddcf47725..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Plain/Internals/AllPackageClasses.cs +++ /dev/null @@ -1,211 +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.Common.Security.Plain.Internals -{ - #region PlainSaslServer - /// - /// - /// - public partial class PlainSaslServer : Javax.Security.Sasl.SaslServer - { - const string _bridgeClassName = "org.apache.kafka.common.security.plain.internals.PlainSaslServer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public PlainSaslServer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public PlainSaslServer(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 PlainSaslServerFactory - /// - /// - /// - public partial class PlainSaslServerFactory : Javax.Security.Sasl.SaslServerFactory - { - const string _bridgeClassName = "org.apache.kafka.common.security.plain.internals.PlainSaslServer$PlainSaslServerFactory"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public PlainSaslServerFactory() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public PlainSaslServerFactory(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 PlainSaslServerProvider - /// - /// - /// - public partial class PlainSaslServerProvider : Java.Security.Provider - { - const string _bridgeClassName = "org.apache.kafka.common.security.plain.internals.PlainSaslServerProvider"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public PlainSaslServerProvider() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public PlainSaslServerProvider(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 PlainServerCallbackHandler - /// - /// - /// - public partial class PlainServerCallbackHandler : Org.Apache.Kafka.Common.Security.Auth.AuthenticateCallbackHandler - { - const string _bridgeClassName = "org.apache.kafka.common.security.plain.internals.PlainServerCallbackHandler"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public PlainServerCallbackHandler() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public PlainServerCallbackHandler(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/Common/Security/Plain/Internals/PlainSaslServer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Plain/Internals/PlainSaslServer.cs index 83e261f05..1492b6948 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Plain/Internals/PlainSaslServer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Plain/Internals/PlainSaslServer.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.Common.Security.Plain.Internals { - #region PlainSaslServer + #region PlainSaslServer declaration + /// + /// + /// + public partial class PlainSaslServer : Javax.Security.Sasl.SaslServer + { + const string _bridgeClassName = "org.apache.kafka.common.security.plain.internals.PlainSaslServer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public PlainSaslServer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public PlainSaslServer(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 PlainSaslServerFactory declaration + /// + /// + /// + public partial class PlainSaslServerFactory : Javax.Security.Sasl.SaslServerFactory + { + const string _bridgeClassName = "org.apache.kafka.common.security.plain.internals.PlainSaslServer$PlainSaslServerFactory"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public PlainSaslServerFactory() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public PlainSaslServerFactory(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 PlainSaslServer implementation public partial class PlainSaslServer { #region Constructors @@ -133,7 +223,7 @@ public object GetNegotiatedProperty(Java.Lang.String arg0) #endregion #region Nested classes - #region PlainSaslServerFactory + #region PlainSaslServerFactory implementation public partial class PlainSaslServerFactory { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Plain/Internals/PlainSaslServerProvider.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Plain/Internals/PlainSaslServerProvider.cs index 6889366ea..f9b1e7c24 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Plain/Internals/PlainSaslServerProvider.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Plain/Internals/PlainSaslServerProvider.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.Common.Security.Plain.Internals { - #region PlainSaslServerProvider + #region PlainSaslServerProvider declaration + /// + /// + /// + public partial class PlainSaslServerProvider : Java.Security.Provider + { + const string _bridgeClassName = "org.apache.kafka.common.security.plain.internals.PlainSaslServerProvider"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public PlainSaslServerProvider() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public PlainSaslServerProvider(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 PlainSaslServerProvider implementation public partial class PlainSaslServerProvider { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Plain/Internals/PlainServerCallbackHandler.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Plain/Internals/PlainServerCallbackHandler.cs index 8a0bf7487..f689b6cdb 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Plain/Internals/PlainServerCallbackHandler.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Plain/Internals/PlainServerCallbackHandler.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.Common.Security.Plain.Internals { - #region PlainServerCallbackHandler + #region PlainServerCallbackHandler declaration + /// + /// + /// + public partial class PlainServerCallbackHandler : Org.Apache.Kafka.Common.Security.Auth.AuthenticateCallbackHandler + { + const string _bridgeClassName = "org.apache.kafka.common.security.plain.internals.PlainServerCallbackHandler"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public PlainServerCallbackHandler() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public PlainServerCallbackHandler(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 PlainServerCallbackHandler implementation public partial class PlainServerCallbackHandler { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Plain/PlainAuthenticateCallback.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Plain/PlainAuthenticateCallback.cs index 0b6349696..b8c9a688e 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Plain/PlainAuthenticateCallback.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Plain/PlainAuthenticateCallback.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.Common.Security.Plain { - #region PlainAuthenticateCallback + #region PlainAuthenticateCallback declaration + /// + /// + /// + public partial class PlainAuthenticateCallback : Javax.Security.Auth.Callback.Callback + { + const string _bridgeClassName = "org.apache.kafka.common.security.plain.PlainAuthenticateCallback"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public PlainAuthenticateCallback() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public PlainAuthenticateCallback(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 PlainAuthenticateCallback implementation public partial class PlainAuthenticateCallback { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Plain/PlainLoginModule.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Plain/PlainLoginModule.cs index 7f7aef70b..4feac6f73 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Plain/PlainLoginModule.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Plain/PlainLoginModule.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.Common.Security.Plain { - #region PlainLoginModule + #region PlainLoginModule declaration + /// + /// + /// + public partial class PlainLoginModule : Javax.Security.Auth.Spi.LoginModule + { + const string _bridgeClassName = "org.apache.kafka.common.security.plain.PlainLoginModule"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public PlainLoginModule() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public PlainLoginModule(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 PlainLoginModule implementation public partial class PlainLoginModule { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Scram/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Scram/AllPackageClasses.cs deleted file mode 100644 index 0458f53b3..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Scram/AllPackageClasses.cs +++ /dev/null @@ -1,211 +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.Common.Security.Scram -{ - #region ScramCredential - /// - /// - /// - public partial class ScramCredential : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.security.scram.ScramCredential"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ScramCredential() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ScramCredential(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 ScramCredentialCallback - /// - /// - /// - public partial class ScramCredentialCallback : Javax.Security.Auth.Callback.Callback - { - const string _bridgeClassName = "org.apache.kafka.common.security.scram.ScramCredentialCallback"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ScramCredentialCallback() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ScramCredentialCallback(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 ScramExtensionsCallback - /// - /// - /// - public partial class ScramExtensionsCallback : Javax.Security.Auth.Callback.Callback - { - const string _bridgeClassName = "org.apache.kafka.common.security.scram.ScramExtensionsCallback"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ScramExtensionsCallback() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ScramExtensionsCallback(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 ScramLoginModule - /// - /// - /// - public partial class ScramLoginModule : Javax.Security.Auth.Spi.LoginModule - { - const string _bridgeClassName = "org.apache.kafka.common.security.scram.ScramLoginModule"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ScramLoginModule() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ScramLoginModule(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/Common/Security/Scram/ScramCredential.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Scram/ScramCredential.cs index 9ac331907..48c4877c5 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Scram/ScramCredential.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Scram/ScramCredential.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.Common.Security.Scram { - #region ScramCredential + #region ScramCredential declaration + /// + /// + /// + public partial class ScramCredential : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.security.scram.ScramCredential"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ScramCredential() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ScramCredential(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 ScramCredential implementation public partial class ScramCredential { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Scram/ScramCredentialCallback.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Scram/ScramCredentialCallback.cs index 8f5676fbf..0b1278f7d 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Scram/ScramCredentialCallback.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Scram/ScramCredentialCallback.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.Common.Security.Scram { - #region ScramCredentialCallback + #region ScramCredentialCallback declaration + /// + /// + /// + public partial class ScramCredentialCallback : Javax.Security.Auth.Callback.Callback + { + const string _bridgeClassName = "org.apache.kafka.common.security.scram.ScramCredentialCallback"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ScramCredentialCallback() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ScramCredentialCallback(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 ScramCredentialCallback implementation public partial class ScramCredentialCallback { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Scram/ScramExtensionsCallback.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Scram/ScramExtensionsCallback.cs index 935e78ff1..919a0d4aa 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Scram/ScramExtensionsCallback.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Scram/ScramExtensionsCallback.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.Common.Security.Scram { - #region ScramExtensionsCallback + #region ScramExtensionsCallback declaration + /// + /// + /// + public partial class ScramExtensionsCallback : Javax.Security.Auth.Callback.Callback + { + const string _bridgeClassName = "org.apache.kafka.common.security.scram.ScramExtensionsCallback"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ScramExtensionsCallback() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ScramExtensionsCallback(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 ScramExtensionsCallback implementation public partial class ScramExtensionsCallback { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Scram/ScramLoginModule.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Scram/ScramLoginModule.cs index 64ffe35d5..6d7505ad0 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Scram/ScramLoginModule.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Scram/ScramLoginModule.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.Common.Security.Scram { - #region ScramLoginModule + #region ScramLoginModule declaration + /// + /// + /// + public partial class ScramLoginModule : Javax.Security.Auth.Spi.LoginModule + { + const string _bridgeClassName = "org.apache.kafka.common.security.scram.ScramLoginModule"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ScramLoginModule() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ScramLoginModule(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 ScramLoginModule implementation public partial class ScramLoginModule { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Ssl/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Ssl/AllPackageClasses.cs deleted file mode 100644 index 684d6227f..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Ssl/AllPackageClasses.cs +++ /dev/null @@ -1,183 +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.Common.Security.Ssl -{ - #region DefaultSslEngineFactory - /// - /// - /// - public partial class DefaultSslEngineFactory : Org.Apache.Kafka.Common.Security.Auth.SslEngineFactory - { - const string _bridgeClassName = "org.apache.kafka.common.security.ssl.DefaultSslEngineFactory"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public DefaultSslEngineFactory() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public DefaultSslEngineFactory(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 SslFactory - /// - /// - /// - public partial class SslFactory : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.security.ssl.SslFactory"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public SslFactory() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public SslFactory(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 SslPrincipalMapper - /// - /// - /// - public partial class SslPrincipalMapper : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.security.ssl.SslPrincipalMapper"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public SslPrincipalMapper() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public SslPrincipalMapper(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 NoMatchingRule - /// - /// - /// - public partial class NoMatchingRule : Java.Io.IOException - { - const string _bridgeClassName = "org.apache.kafka.common.security.ssl.SslPrincipalMapper$NoMatchingRule"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - - } - #endregion - - - -} \ No newline at end of file diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Ssl/DefaultSslEngineFactory.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Ssl/DefaultSslEngineFactory.cs index e7f02281c..f63c21e5a 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Ssl/DefaultSslEngineFactory.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Ssl/DefaultSslEngineFactory.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.Common.Security.Ssl { - #region DefaultSslEngineFactory + #region DefaultSslEngineFactory declaration + /// + /// + /// + public partial class DefaultSslEngineFactory : Org.Apache.Kafka.Common.Security.Auth.SslEngineFactory + { + const string _bridgeClassName = "org.apache.kafka.common.security.ssl.DefaultSslEngineFactory"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public DefaultSslEngineFactory() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public DefaultSslEngineFactory(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 DefaultSslEngineFactory implementation public partial class DefaultSslEngineFactory { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Ssl/SslFactory.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Ssl/SslFactory.cs index 5e829a770..c85885123 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Ssl/SslFactory.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Ssl/SslFactory.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.Common.Security.Ssl { - #region SslFactory + #region SslFactory declaration + /// + /// + /// + public partial class SslFactory : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.security.ssl.SslFactory"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public SslFactory() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public SslFactory(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 SslFactory implementation public partial class SslFactory : Org.Apache.Kafka.Common.IReconfigurable, Java.Io.ICloseable { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Ssl/SslPrincipalMapper.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Ssl/SslPrincipalMapper.cs index d0d3359d7..6ba2dc107 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Ssl/SslPrincipalMapper.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Ssl/SslPrincipalMapper.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,69 @@ namespace Org.Apache.Kafka.Common.Security.Ssl { - #region SslPrincipalMapper + #region SslPrincipalMapper declaration + /// + /// + /// + public partial class SslPrincipalMapper : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.security.ssl.SslPrincipalMapper"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public SslPrincipalMapper() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public SslPrincipalMapper(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 NoMatchingRule declaration + /// + /// + /// + public partial class NoMatchingRule : Java.Io.IOException + { + const string _bridgeClassName = "org.apache.kafka.common.security.ssl.SslPrincipalMapper$NoMatchingRule"; + /// + /// + /// + public override string BridgeClassName => _bridgeClassName; + + // TODO: complete the class + + } + #endregion + + + } + #endregion + + #region SslPrincipalMapper implementation public partial class SslPrincipalMapper { #region Constructors @@ -76,7 +138,7 @@ public Java.Lang.String GetName(Java.Lang.String arg0) #endregion #region Nested classes - #region NoMatchingRule + #region NoMatchingRule implementation public partial class NoMatchingRule { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Token/Delegation/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Token/Delegation/AllPackageClasses.cs deleted file mode 100644 index 8b45d733a..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Token/Delegation/AllPackageClasses.cs +++ /dev/null @@ -1,121 +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.Common.Security.Token.Delegation -{ - #region DelegationToken - /// - /// - /// - public partial class DelegationToken : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.security.token.delegation.DelegationToken"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public DelegationToken() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public DelegationToken(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 TokenInformation - /// - /// - /// - public partial class TokenInformation : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.security.token.delegation.TokenInformation"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public TokenInformation() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public TokenInformation(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/Common/Security/Token/Delegation/DelegationToken.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Token/Delegation/DelegationToken.cs index 4b9f3e8c7..fe6677df5 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Token/Delegation/DelegationToken.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Token/Delegation/DelegationToken.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.Common.Security.Token.Delegation { - #region DelegationToken + #region DelegationToken declaration + /// + /// + /// + public partial class DelegationToken : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.security.token.delegation.DelegationToken"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public DelegationToken() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public DelegationToken(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 DelegationToken implementation public partial class DelegationToken { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Token/Delegation/TokenInformation.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Token/Delegation/TokenInformation.cs index bb100402b..867d9c1b7 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Token/Delegation/TokenInformation.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Token/Delegation/TokenInformation.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.Common.Security.Token.Delegation { - #region TokenInformation + #region TokenInformation declaration + /// + /// + /// + public partial class TokenInformation : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.security.token.delegation.TokenInformation"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public TokenInformation() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public TokenInformation(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 TokenInformation implementation public partial class TokenInformation { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/AllPackageClasses.cs deleted file mode 100644 index 54c30ddcd..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/AllPackageClasses.cs +++ /dev/null @@ -1,2420 +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.Common.Serialization -{ - #region BooleanDeserializer - /// - /// - /// - public partial class BooleanDeserializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.BooleanDeserializer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public BooleanDeserializer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public BooleanDeserializer(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 BooleanSerializer - /// - /// - /// - public partial class BooleanSerializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.BooleanSerializer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public BooleanSerializer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public BooleanSerializer(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 ByteArrayDeserializer - /// - /// - /// - public partial class ByteArrayDeserializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.ByteArrayDeserializer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ByteArrayDeserializer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ByteArrayDeserializer(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 ByteArraySerializer - /// - /// - /// - public partial class ByteArraySerializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.ByteArraySerializer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ByteArraySerializer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ByteArraySerializer(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 ByteBufferDeserializer - /// - /// - /// - public partial class ByteBufferDeserializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.ByteBufferDeserializer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ByteBufferDeserializer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ByteBufferDeserializer(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 ByteBufferSerializer - /// - /// - /// - public partial class ByteBufferSerializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.ByteBufferSerializer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ByteBufferSerializer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ByteBufferSerializer(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 BytesDeserializer - /// - /// - /// - public partial class BytesDeserializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.BytesDeserializer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public BytesDeserializer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public BytesDeserializer(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 BytesSerializer - /// - /// - /// - public partial class BytesSerializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.BytesSerializer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public BytesSerializer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public BytesSerializer(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 Deserializer - /// - /// - /// - public partial class Deserializer : MASES.JCOBridge.C2JBridge.JVMBridgeListener - { - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Deserializer() { InitializeHandlers(); } - - const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.common.serialization.Deserializer"; - 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; - - - // TODO: complete the class - - } - #endregion - - #region DeserializerDirect - /// - /// Direct override of or its generic type if there is one - /// - public partial class DeserializerDirect : Deserializer - { - /// - /// - /// - public override bool AutoInit => false; - - /// - protected override void InitializeHandlers() { } - - const string _bridgeClassName = "org.apache.kafka.common.serialization.Deserializer"; - 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; - } - #endregion - - #region Deserializer - /// - /// - /// - /// - public partial class Deserializer : MASES.JCOBridge.C2JBridge.JVMBridgeListener - { - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Deserializer() { InitializeHandlers(); } - - const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.common.serialization.Deserializer"; - 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; - - - // TODO: complete the class - - } - #endregion - - #region DeserializerDirect - /// - /// Direct override of or its generic type if there is one - /// - public partial class DeserializerDirect : Deserializer - { - /// - /// - /// - public override bool AutoInit => false; - - /// - protected override void InitializeHandlers() { } - - const string _bridgeClassName = "org.apache.kafka.common.serialization.Deserializer"; - 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; - } - #endregion - - #region DoubleDeserializer - /// - /// - /// - public partial class DoubleDeserializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.DoubleDeserializer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public DoubleDeserializer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public DoubleDeserializer(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 DoubleSerializer - /// - /// - /// - public partial class DoubleSerializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.DoubleSerializer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public DoubleSerializer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public DoubleSerializer(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 FloatDeserializer - /// - /// - /// - public partial class FloatDeserializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.FloatDeserializer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public FloatDeserializer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public FloatDeserializer(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 FloatSerializer - /// - /// - /// - public partial class FloatSerializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.FloatSerializer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public FloatSerializer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public FloatSerializer(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 IntegerDeserializer - /// - /// - /// - public partial class IntegerDeserializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.IntegerDeserializer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public IntegerDeserializer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public IntegerDeserializer(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 IntegerSerializer - /// - /// - /// - public partial class IntegerSerializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.IntegerSerializer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public IntegerSerializer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public IntegerSerializer(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 ListDeserializer - /// - /// - /// - public partial class ListDeserializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.ListDeserializer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ListDeserializer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ListDeserializer(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 ListDeserializer - /// - /// - /// - /// - public partial class ListDeserializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase> - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.ListDeserializer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ListDeserializer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ListDeserializer(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 ListSerializer - /// - /// - /// - public partial class ListSerializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.ListSerializer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ListSerializer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ListSerializer(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 ListSerializer - /// - /// - /// - /// - public partial class ListSerializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase> - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.ListSerializer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ListSerializer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ListSerializer(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 LongDeserializer - /// - /// - /// - public partial class LongDeserializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.LongDeserializer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public LongDeserializer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public LongDeserializer(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 LongSerializer - /// - /// - /// - public partial class LongSerializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.LongSerializer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public LongSerializer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public LongSerializer(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 Serde - /// - /// - /// - public partial class Serde : MASES.JCOBridge.C2JBridge.JVMBridgeListener - { - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Serde() { InitializeHandlers(); } - - const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.common.serialization.Serde"; - 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; - - - // TODO: complete the class - - } - #endregion - - #region SerdeDirect - /// - /// Direct override of or its generic type if there is one - /// - public partial class SerdeDirect : Serde - { - /// - /// - /// - public override bool AutoInit => false; - - /// - protected override void InitializeHandlers() { } - - const string _bridgeClassName = "org.apache.kafka.common.serialization.Serde"; - 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; - } - #endregion - - #region Serde - /// - /// - /// - /// - public partial class Serde : MASES.JCOBridge.C2JBridge.JVMBridgeListener - { - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Serde() { InitializeHandlers(); } - - const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.common.serialization.Serde"; - 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; - - - // TODO: complete the class - - } - #endregion - - #region SerdeDirect - /// - /// Direct override of or its generic type if there is one - /// - public partial class SerdeDirect : Serde - { - /// - /// - /// - public override bool AutoInit => false; - - /// - protected override void InitializeHandlers() { } - - const string _bridgeClassName = "org.apache.kafka.common.serialization.Serde"; - 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; - } - #endregion - - #region Serdes - /// - /// - /// - public partial class Serdes : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Serdes() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Serdes(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 BooleanSerde - /// - /// - /// - public partial class BooleanSerde : Org.Apache.Kafka.Common.Serialization.Serdes.WrapperSerde - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$BooleanSerde"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public BooleanSerde() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public BooleanSerde(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 ByteArraySerde - /// - /// - /// - public partial class ByteArraySerde : Org.Apache.Kafka.Common.Serialization.Serdes.WrapperSerde - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$ByteArraySerde"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ByteArraySerde() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ByteArraySerde(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 ByteBufferSerde - /// - /// - /// - public partial class ByteBufferSerde : Org.Apache.Kafka.Common.Serialization.Serdes.WrapperSerde - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$ByteBufferSerde"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ByteBufferSerde() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ByteBufferSerde(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 BytesSerde - /// - /// - /// - public partial class BytesSerde : Org.Apache.Kafka.Common.Serialization.Serdes.WrapperSerde - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$BytesSerde"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public BytesSerde() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public BytesSerde(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 DoubleSerde - /// - /// - /// - public partial class DoubleSerde : Org.Apache.Kafka.Common.Serialization.Serdes.WrapperSerde - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$DoubleSerde"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public DoubleSerde() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public DoubleSerde(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 FloatSerde - /// - /// - /// - public partial class FloatSerde : Org.Apache.Kafka.Common.Serialization.Serdes.WrapperSerde - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$FloatSerde"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public FloatSerde() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public FloatSerde(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 IntegerSerde - /// - /// - /// - public partial class IntegerSerde : Org.Apache.Kafka.Common.Serialization.Serdes.WrapperSerde - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$IntegerSerde"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public IntegerSerde() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public IntegerSerde(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 ListSerde - /// - /// - /// - public partial class ListSerde : Org.Apache.Kafka.Common.Serialization.Serdes.WrapperSerde - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$ListSerde"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ListSerde() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ListSerde(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 ListSerde - /// - /// - /// - /// - public partial class ListSerde : Org.Apache.Kafka.Common.Serialization.Serdes.WrapperSerde> - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$ListSerde"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ListSerde() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ListSerde(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 LongSerde - /// - /// - /// - public partial class LongSerde : Org.Apache.Kafka.Common.Serialization.Serdes.WrapperSerde - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$LongSerde"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public LongSerde() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public LongSerde(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 ShortSerde - /// - /// - /// - public partial class ShortSerde : Org.Apache.Kafka.Common.Serialization.Serdes.WrapperSerde - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$ShortSerde"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ShortSerde() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ShortSerde(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 StringSerde - /// - /// - /// - public partial class StringSerde : Org.Apache.Kafka.Common.Serialization.Serdes.WrapperSerde - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$StringSerde"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public StringSerde() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public StringSerde(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 UUIDSerde - /// - /// - /// - public partial class UUIDSerde : Org.Apache.Kafka.Common.Serialization.Serdes.WrapperSerde - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$UUIDSerde"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public UUIDSerde() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public UUIDSerde(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 VoidSerde - /// - /// - /// - public partial class VoidSerde : Org.Apache.Kafka.Common.Serialization.Serdes.WrapperSerde - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$VoidSerde"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public VoidSerde() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public VoidSerde(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 WrapperSerde - /// - /// - /// - public partial class WrapperSerde : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$WrapperSerde"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public WrapperSerde() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public WrapperSerde(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 WrapperSerde - /// - /// - /// - /// - public partial class WrapperSerde : MASES.JCOBridge.C2JBridge.JVMBridgeBase> - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$WrapperSerde"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public WrapperSerde() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public WrapperSerde(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 Serializer - /// - /// - /// - public partial class Serializer : MASES.JCOBridge.C2JBridge.JVMBridgeListener - { - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Serializer() { InitializeHandlers(); } - - const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.common.serialization.Serializer"; - 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; - - - // TODO: complete the class - - } - #endregion - - #region SerializerDirect - /// - /// Direct override of or its generic type if there is one - /// - public partial class SerializerDirect : Serializer - { - /// - /// - /// - public override bool AutoInit => false; - - /// - protected override void InitializeHandlers() { } - - const string _bridgeClassName = "org.apache.kafka.common.serialization.Serializer"; - 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; - } - #endregion - - #region Serializer - /// - /// - /// - /// - public partial class Serializer : MASES.JCOBridge.C2JBridge.JVMBridgeListener - { - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Serializer() { InitializeHandlers(); } - - const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.common.serialization.Serializer"; - 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; - - - // TODO: complete the class - - } - #endregion - - #region SerializerDirect - /// - /// Direct override of or its generic type if there is one - /// - public partial class SerializerDirect : Serializer - { - /// - /// - /// - public override bool AutoInit => false; - - /// - protected override void InitializeHandlers() { } - - const string _bridgeClassName = "org.apache.kafka.common.serialization.Serializer"; - 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; - } - #endregion - - #region ShortDeserializer - /// - /// - /// - public partial class ShortDeserializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.ShortDeserializer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ShortDeserializer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ShortDeserializer(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 ShortSerializer - /// - /// - /// - public partial class ShortSerializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.ShortSerializer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ShortSerializer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ShortSerializer(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 StringDeserializer - /// - /// - /// - public partial class StringDeserializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.StringDeserializer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public StringDeserializer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public StringDeserializer(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 StringSerializer - /// - /// - /// - public partial class StringSerializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.StringSerializer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public StringSerializer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public StringSerializer(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 UUIDDeserializer - /// - /// - /// - public partial class UUIDDeserializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.UUIDDeserializer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public UUIDDeserializer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public UUIDDeserializer(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 UUIDSerializer - /// - /// - /// - public partial class UUIDSerializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.UUIDSerializer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public UUIDSerializer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public UUIDSerializer(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 VoidDeserializer - /// - /// - /// - public partial class VoidDeserializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.serialization.VoidDeserializer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public VoidDeserializer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public VoidDeserializer(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/Common/Serialization/BooleanDeserializer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/BooleanDeserializer.cs index 7b55b7a08..9cf5928d4 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/BooleanDeserializer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/BooleanDeserializer.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.Common.Serialization { - #region BooleanDeserializer + #region BooleanDeserializer declaration + /// + /// + /// + public partial class BooleanDeserializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.BooleanDeserializer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public BooleanDeserializer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public BooleanDeserializer(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 BooleanDeserializer implementation public partial class BooleanDeserializer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/BooleanSerializer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/BooleanSerializer.cs index ea3862816..995ffac85 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/BooleanSerializer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/BooleanSerializer.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.Common.Serialization { - #region BooleanSerializer + #region BooleanSerializer declaration + /// + /// + /// + public partial class BooleanSerializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.BooleanSerializer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public BooleanSerializer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public BooleanSerializer(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 BooleanSerializer implementation public partial class BooleanSerializer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ByteArrayDeserializer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ByteArrayDeserializer.cs index 0174003d6..215ccfb5d 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ByteArrayDeserializer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ByteArrayDeserializer.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.Common.Serialization { - #region ByteArrayDeserializer + #region ByteArrayDeserializer declaration + /// + /// + /// + public partial class ByteArrayDeserializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.ByteArrayDeserializer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ByteArrayDeserializer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ByteArrayDeserializer(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 ByteArrayDeserializer implementation public partial class ByteArrayDeserializer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ByteArraySerializer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ByteArraySerializer.cs index f544adc27..6b3c1e4b8 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ByteArraySerializer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ByteArraySerializer.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.Common.Serialization { - #region ByteArraySerializer + #region ByteArraySerializer declaration + /// + /// + /// + public partial class ByteArraySerializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.ByteArraySerializer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ByteArraySerializer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ByteArraySerializer(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 ByteArraySerializer implementation public partial class ByteArraySerializer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ByteBufferDeserializer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ByteBufferDeserializer.cs index a191b32de..21ffd0c6e 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ByteBufferDeserializer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ByteBufferDeserializer.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.Common.Serialization { - #region ByteBufferDeserializer + #region ByteBufferDeserializer declaration + /// + /// + /// + public partial class ByteBufferDeserializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.ByteBufferDeserializer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ByteBufferDeserializer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ByteBufferDeserializer(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 ByteBufferDeserializer implementation public partial class ByteBufferDeserializer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ByteBufferSerializer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ByteBufferSerializer.cs index 149a21a3c..3f4d957f7 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ByteBufferSerializer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ByteBufferSerializer.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.Common.Serialization { - #region ByteBufferSerializer + #region ByteBufferSerializer declaration + /// + /// + /// + public partial class ByteBufferSerializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.ByteBufferSerializer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ByteBufferSerializer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ByteBufferSerializer(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 ByteBufferSerializer implementation public partial class ByteBufferSerializer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/BytesDeserializer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/BytesDeserializer.cs index 6338c4c0e..e3be1fe98 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/BytesDeserializer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/BytesDeserializer.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.Common.Serialization { - #region BytesDeserializer + #region BytesDeserializer declaration + /// + /// + /// + public partial class BytesDeserializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.BytesDeserializer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public BytesDeserializer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public BytesDeserializer(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 BytesDeserializer implementation public partial class BytesDeserializer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/BytesSerializer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/BytesSerializer.cs index 21a827b37..0cbbe7abe 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/BytesSerializer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/BytesSerializer.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.Common.Serialization { - #region BytesSerializer + #region BytesSerializer declaration + /// + /// + /// + public partial class BytesSerializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.BytesSerializer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public BytesSerializer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public BytesSerializer(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 BytesSerializer implementation public partial class BytesSerializer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/Deserializer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/Deserializer.cs index d8c0a6b58..52f2d89da 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/Deserializer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/Deserializer.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,142 @@ namespace Org.Apache.Kafka.Common.Serialization { - #region Deserializer + #region Deserializer declaration + /// + /// + /// + public partial class Deserializer : MASES.JCOBridge.C2JBridge.JVMBridgeListener + { + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Deserializer() { InitializeHandlers(); } + + const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.common.serialization.Deserializer"; + private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = 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; + + + // TODO: complete the class + + } + #endregion + + #region DeserializerDirect declaration + /// + /// Direct override of or its generic type if there is one + /// + public partial class DeserializerDirect : Deserializer + { + /// + /// + /// + public override bool AutoInit => false; + + /// + protected override void InitializeHandlers() { } + + const string _bridgeClassName = "org.apache.kafka.common.serialization.Deserializer"; + 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; + } + #endregion + + #region Deserializer declaration + /// + /// + /// + /// + public partial class Deserializer : MASES.JCOBridge.C2JBridge.JVMBridgeListener + { + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Deserializer() { InitializeHandlers(); } + + const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.common.serialization.Deserializer"; + private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = 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; + + + // TODO: complete the class + + } + #endregion + + #region DeserializerDirect declaration + /// + /// Direct override of or its generic type if there is one + /// + public partial class DeserializerDirect : Deserializer + { + /// + /// + /// + public override bool AutoInit => false; + + /// + protected override void InitializeHandlers() { } + + const string _bridgeClassName = "org.apache.kafka.common.serialization.Deserializer"; + 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; + } + #endregion + + #region Deserializer implementation public partial class Deserializer { #region Constructors @@ -50,11 +185,11 @@ public partial class Deserializer /// protected virtual void InitializeHandlers() { - AddEventHandler("deserialize", new global::System.EventHandler>>(DeserializeEventHandler)); - AddEventHandler("deserialize3", new global::System.EventHandler>>(Deserialize3EventHandler)); - AddEventHandler("deserialize3_2", new global::System.EventHandler>>(Deserialize3_2EventHandler)); - AddEventHandler("close", new global::System.EventHandler>(CloseEventHandler)); - AddEventHandler("configure", new global::System.EventHandler>>(ConfigureEventHandler)); + AddEventHandler("deserialize", new global::System.EventHandler>>(DeserializeEventHandler)); + AddEventHandler("deserialize3", new global::System.EventHandler>>(Deserialize3EventHandler)); + AddEventHandler("deserialize3_2", new global::System.EventHandler>>(Deserialize3_2EventHandler)); + AddEventHandler("close", new global::System.EventHandler>>(CloseEventHandler)); + AddEventHandler("configure", new global::System.EventHandler>>(ConfigureEventHandler)); } @@ -64,11 +199,13 @@ protected virtual void InitializeHandlers() /// If has a value it takes precedence over corresponding class method public global::System.Func OnDeserialize { get; set; } = null; - void DeserializeEventHandler(object sender, CLRListenerEventArgs> data) + bool hasOverrideDeserialize = true; + void DeserializeEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideDeserialize = true; var methodToExecute = (OnDeserialize != null) ? OnDeserialize : Deserialize; - var executionResult = methodToExecute.Invoke(data.EventData.TypedEventData, data.EventData.GetAt(0)); - data.SetReturnValue(executionResult); + var executionResult = methodToExecute.Invoke(data.EventData.GetAt(0), data.EventData.GetAt(1)); + data.EventData.TypedEventData.SetReturnData(hasOverrideDeserialize, executionResult); } /// @@ -79,7 +216,7 @@ void DeserializeEventHandler(object sender, CLRListenerEventArgs public virtual object Deserialize(Java.Lang.String arg0, byte[] arg1) { - return default; + hasOverrideDeserialize = false; return default; } /// /// @@ -100,11 +237,13 @@ public object DeserializeDefault(Java.Lang.String arg0, Org.Apache.Kafka.Common. /// If has a value it takes precedence over corresponding class method public global::System.Func OnDeserialize3 { get; set; } = null; - void Deserialize3EventHandler(object sender, CLRListenerEventArgs> data) + bool hasOverrideDeserialize3 = true; + void Deserialize3EventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideDeserialize3 = true; var methodToExecute = (OnDeserialize3 != null) ? OnDeserialize3 : Deserialize; - var executionResult = methodToExecute.Invoke(data.EventData.TypedEventData, data.EventData.GetAt(0), data.EventData.GetAt(1)); - data.SetReturnValue(executionResult); + var executionResult = methodToExecute.Invoke(data.EventData.GetAt(0), data.EventData.GetAt(1), data.EventData.GetAt(2)); + data.EventData.TypedEventData.SetReturnData(hasOverrideDeserialize3, executionResult); } /// @@ -117,7 +256,7 @@ void Deserialize3EventHandler(object sender, CLRListenerEventArgsThe method invokes the default implementation in the JVM interface using ; override the method to implement a different behavior public virtual object Deserialize(Java.Lang.String arg0, Org.Apache.Kafka.Common.Header.Headers arg1, byte[] arg2) { - return DeserializeDefault(arg0, arg1, arg2); + hasOverrideDeserialize3 = false; return default; } /// /// @@ -138,11 +277,13 @@ public object DeserializeDefault(Java.Lang.String arg0, Org.Apache.Kafka.Common. /// If has a value it takes precedence over corresponding class method public global::System.Func OnDeserialize3_2 { get; set; } = null; - void Deserialize3_2EventHandler(object sender, CLRListenerEventArgs> data) + bool hasOverrideDeserialize3_2 = true; + void Deserialize3_2EventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideDeserialize3_2 = true; var methodToExecute = (OnDeserialize3_2 != null) ? OnDeserialize3_2 : Deserialize; - var executionResult = methodToExecute.Invoke(data.EventData.TypedEventData, data.EventData.GetAt(0), data.EventData.GetAt(1)); - data.SetReturnValue(executionResult); + var executionResult = methodToExecute.Invoke(data.EventData.GetAt(0), data.EventData.GetAt(1), data.EventData.GetAt(2)); + data.EventData.TypedEventData.SetReturnData(hasOverrideDeserialize3_2, executionResult); } /// @@ -155,7 +296,7 @@ void Deserialize3_2EventHandler(object sender, CLRListenerEventArgsThe method invokes the default implementation in the JVM interface using ; override the method to implement a different behavior public virtual object Deserialize(Java.Lang.String arg0, Org.Apache.Kafka.Common.Header.Headers arg1, Java.Nio.ByteBuffer arg2) { - return DeserializeDefault(arg0, arg1, arg2); + hasOverrideDeserialize3_2 = false; return default; } /// /// @@ -172,10 +313,13 @@ public void CloseDefault() /// If has a value it takes precedence over corresponding class method public global::System.Action OnClose { get; set; } = null; - void CloseEventHandler(object sender, CLRListenerEventArgs data) + bool hasOverrideClose = true; + void CloseEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideClose = true; var methodToExecute = (OnClose != null) ? OnClose : Close; methodToExecute.Invoke(); + data.EventData.TypedEventData.HasOverride = hasOverrideClose; } /// @@ -184,7 +328,7 @@ void CloseEventHandler(object sender, CLRListenerEventArgs data) /// The method invokes the default implementation in the JVM interface using ; override the method to implement a different behavior public virtual void Close() { - CloseDefault(); + hasOverrideClose = false; } /// /// @@ -203,10 +347,13 @@ public void ConfigureDefault(Java.Util.Map arg0, bool arg1) /// If has a value it takes precedence over corresponding class method public global::System.Action OnConfigure { get; set; } = null; - void ConfigureEventHandler(object sender, CLRListenerEventArgs> data) + bool hasOverrideConfigure = true; + void ConfigureEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideConfigure = true; var methodToExecute = (OnConfigure != null) ? OnConfigure : Configure; - methodToExecute.Invoke(data.EventData.TypedEventData, data.EventData.GetAt(0)); + methodToExecute.Invoke(data.EventData.GetAt(0), data.EventData.GetAt(1)); + data.EventData.TypedEventData.HasOverride = hasOverrideConfigure; } /// @@ -217,7 +364,7 @@ void ConfigureEventHandler(object sender, CLRListenerEventArgsThe method invokes the default implementation in the JVM interface using ; override the method to implement a different behavior public virtual void Configure(Java.Util.Map arg0, bool arg1) { - ConfigureDefault(arg0, arg1); + hasOverrideConfigure = false; } #endregion @@ -230,7 +377,7 @@ public virtual void Configure(Java.Util.Map arg0, bool arg1) } #endregion - #region DeserializerDirect + #region DeserializerDirect implementation public partial class DeserializerDirect { #region Constructors @@ -327,7 +474,7 @@ public partial interface IDeserializer } #endregion - #region Deserializer + #region Deserializer implementation public partial class Deserializer : Org.Apache.Kafka.Common.Serialization.IDeserializer { #region Constructors @@ -352,11 +499,11 @@ public partial class Deserializer : Org.Apache.Kafka.Common.Serialization.IDe /// protected virtual void InitializeHandlers() { - AddEventHandler("deserialize", new global::System.EventHandler>>(DeserializeEventHandler)); - AddEventHandler("deserialize3", new global::System.EventHandler>>(Deserialize3EventHandler)); - AddEventHandler("deserialize3_2", new global::System.EventHandler>>(Deserialize3_2EventHandler)); - AddEventHandler("close", new global::System.EventHandler>(CloseEventHandler)); - AddEventHandler("configure", new global::System.EventHandler>>>(ConfigureEventHandler)); + AddEventHandler("deserialize", new global::System.EventHandler>>(DeserializeEventHandler)); + AddEventHandler("deserialize3", new global::System.EventHandler>>(Deserialize3EventHandler)); + AddEventHandler("deserialize3_2", new global::System.EventHandler>>(Deserialize3_2EventHandler)); + AddEventHandler("close", new global::System.EventHandler>>(CloseEventHandler)); + AddEventHandler("configure", new global::System.EventHandler>>(ConfigureEventHandler)); } @@ -366,11 +513,13 @@ protected virtual void InitializeHandlers() /// If has a value it takes precedence over corresponding class method public global::System.Func OnDeserialize { get; set; } = null; - void DeserializeEventHandler(object sender, CLRListenerEventArgs> data) + bool hasOverrideDeserialize = true; + void DeserializeEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideDeserialize = true; var methodToExecute = (OnDeserialize != null) ? OnDeserialize : Deserialize; - var executionResult = methodToExecute.Invoke(data.EventData.TypedEventData, data.EventData.GetAt(0)); - data.SetReturnValue(executionResult); + var executionResult = methodToExecute.Invoke(data.EventData.GetAt(0), data.EventData.GetAt(1)); + data.EventData.TypedEventData.SetReturnData(hasOverrideDeserialize, executionResult); } /// @@ -381,7 +530,7 @@ void DeserializeEventHandler(object sender, CLRListenerEventArgs public virtual T Deserialize(Java.Lang.String arg0, byte[] arg1) { - return default; + hasOverrideDeserialize = false; return default; } /// /// @@ -402,11 +551,13 @@ public T DeserializeDefault(Java.Lang.String arg0, Org.Apache.Kafka.Common.Heade /// If has a value it takes precedence over corresponding class method public global::System.Func OnDeserialize3 { get; set; } = null; - void Deserialize3EventHandler(object sender, CLRListenerEventArgs> data) + bool hasOverrideDeserialize3 = true; + void Deserialize3EventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideDeserialize3 = true; var methodToExecute = (OnDeserialize3 != null) ? OnDeserialize3 : Deserialize; - var executionResult = methodToExecute.Invoke(data.EventData.TypedEventData, data.EventData.GetAt(0), data.EventData.GetAt(1)); - data.SetReturnValue(executionResult); + var executionResult = methodToExecute.Invoke(data.EventData.GetAt(0), data.EventData.GetAt(1), data.EventData.GetAt(2)); + data.EventData.TypedEventData.SetReturnData(hasOverrideDeserialize3, executionResult); } /// @@ -419,7 +570,7 @@ void Deserialize3EventHandler(object sender, CLRListenerEventArgsThe method invokes the default implementation in the JVM interface using ; override the method to implement a different behavior public virtual T Deserialize(Java.Lang.String arg0, Org.Apache.Kafka.Common.Header.Headers arg1, byte[] arg2) { - return DeserializeDefault(arg0, arg1, arg2); + hasOverrideDeserialize3 = false; return default; } /// /// @@ -440,11 +591,13 @@ public T DeserializeDefault(Java.Lang.String arg0, Org.Apache.Kafka.Common.Heade /// If has a value it takes precedence over corresponding class method public global::System.Func OnDeserialize3_2 { get; set; } = null; - void Deserialize3_2EventHandler(object sender, CLRListenerEventArgs> data) + bool hasOverrideDeserialize3_2 = true; + void Deserialize3_2EventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideDeserialize3_2 = true; var methodToExecute = (OnDeserialize3_2 != null) ? OnDeserialize3_2 : Deserialize; - var executionResult = methodToExecute.Invoke(data.EventData.TypedEventData, data.EventData.GetAt(0), data.EventData.GetAt(1)); - data.SetReturnValue(executionResult); + var executionResult = methodToExecute.Invoke(data.EventData.GetAt(0), data.EventData.GetAt(1), data.EventData.GetAt(2)); + data.EventData.TypedEventData.SetReturnData(hasOverrideDeserialize3_2, executionResult); } /// @@ -457,7 +610,7 @@ void Deserialize3_2EventHandler(object sender, CLRListenerEventArgsThe method invokes the default implementation in the JVM interface using ; override the method to implement a different behavior public virtual T Deserialize(Java.Lang.String arg0, Org.Apache.Kafka.Common.Header.Headers arg1, Java.Nio.ByteBuffer arg2) { - return DeserializeDefault(arg0, arg1, arg2); + hasOverrideDeserialize3_2 = false; return default; } /// /// @@ -474,10 +627,13 @@ public void CloseDefault() /// If has a value it takes precedence over corresponding class method public global::System.Action OnClose { get; set; } = null; - void CloseEventHandler(object sender, CLRListenerEventArgs data) + bool hasOverrideClose = true; + void CloseEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideClose = true; var methodToExecute = (OnClose != null) ? OnClose : Close; methodToExecute.Invoke(); + data.EventData.TypedEventData.HasOverride = hasOverrideClose; } /// @@ -486,7 +642,7 @@ void CloseEventHandler(object sender, CLRListenerEventArgs data) /// The method invokes the default implementation in the JVM interface using ; override the method to implement a different behavior public virtual void Close() { - CloseDefault(); + hasOverrideClose = false; } /// /// @@ -505,10 +661,13 @@ public void ConfigureDefault(Java.Util.Map arg0, bool /// If has a value it takes precedence over corresponding class method public global::System.Action, bool> OnConfigure { get; set; } = null; - void ConfigureEventHandler(object sender, CLRListenerEventArgs>> data) + bool hasOverrideConfigure = true; + void ConfigureEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideConfigure = true; var methodToExecute = (OnConfigure != null) ? OnConfigure : Configure; - methodToExecute.Invoke(data.EventData.TypedEventData, data.EventData.GetAt(0)); + methodToExecute.Invoke(data.EventData.GetAt>(0), data.EventData.GetAt(1)); + data.EventData.TypedEventData.HasOverride = hasOverrideConfigure; } /// @@ -519,7 +678,7 @@ void ConfigureEventHandler(object sender, CLRListenerEventArgsThe method invokes the default implementation in the JVM interface using ; override the method to implement a different behavior public virtual void Configure(Java.Util.Map arg0, bool arg1) { - ConfigureDefault(arg0, arg1); + hasOverrideConfigure = false; } #endregion @@ -532,7 +691,7 @@ public virtual void Configure(Java.Util.Map arg0, bool } #endregion - #region DeserializerDirect + #region DeserializerDirect implementation public partial class DeserializerDirect : Org.Apache.Kafka.Common.Serialization.IDeserializer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/DoubleDeserializer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/DoubleDeserializer.cs index 27d6a6004..a42d34276 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/DoubleDeserializer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/DoubleDeserializer.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.Common.Serialization { - #region DoubleDeserializer + #region DoubleDeserializer declaration + /// + /// + /// + public partial class DoubleDeserializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.DoubleDeserializer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public DoubleDeserializer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public DoubleDeserializer(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 DoubleDeserializer implementation public partial class DoubleDeserializer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/DoubleSerializer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/DoubleSerializer.cs index 638cf0b22..aa438b5bf 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/DoubleSerializer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/DoubleSerializer.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.Common.Serialization { - #region DoubleSerializer + #region DoubleSerializer declaration + /// + /// + /// + public partial class DoubleSerializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.DoubleSerializer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public DoubleSerializer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public DoubleSerializer(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 DoubleSerializer implementation public partial class DoubleSerializer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/FloatDeserializer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/FloatDeserializer.cs index 51122e87d..d5ada57a2 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/FloatDeserializer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/FloatDeserializer.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.Common.Serialization { - #region FloatDeserializer + #region FloatDeserializer declaration + /// + /// + /// + public partial class FloatDeserializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.FloatDeserializer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public FloatDeserializer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public FloatDeserializer(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 FloatDeserializer implementation public partial class FloatDeserializer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/FloatSerializer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/FloatSerializer.cs index 7d0d0cdbe..ddae3877d 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/FloatSerializer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/FloatSerializer.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.Common.Serialization { - #region FloatSerializer + #region FloatSerializer declaration + /// + /// + /// + public partial class FloatSerializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.FloatSerializer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public FloatSerializer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public FloatSerializer(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 FloatSerializer implementation public partial class FloatSerializer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/IntegerDeserializer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/IntegerDeserializer.cs index 232d86918..c904d721f 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/IntegerDeserializer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/IntegerDeserializer.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.Common.Serialization { - #region IntegerDeserializer + #region IntegerDeserializer declaration + /// + /// + /// + public partial class IntegerDeserializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.IntegerDeserializer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public IntegerDeserializer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public IntegerDeserializer(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 IntegerDeserializer implementation public partial class IntegerDeserializer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/IntegerSerializer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/IntegerSerializer.cs index 96fe9cd21..cce37f9a3 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/IntegerSerializer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/IntegerSerializer.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.Common.Serialization { - #region IntegerSerializer + #region IntegerSerializer declaration + /// + /// + /// + public partial class IntegerSerializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.IntegerSerializer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public IntegerSerializer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public IntegerSerializer(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 IntegerSerializer implementation public partial class IntegerSerializer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ListDeserializer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ListDeserializer.cs index 6d64f05ce..baf53bb8d 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ListDeserializer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ListDeserializer.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,98 @@ namespace Org.Apache.Kafka.Common.Serialization { - #region ListDeserializer + #region ListDeserializer declaration + /// + /// + /// + public partial class ListDeserializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.ListDeserializer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ListDeserializer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ListDeserializer(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 ListDeserializer declaration + /// + /// + /// + /// + public partial class ListDeserializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase> + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.ListDeserializer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ListDeserializer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ListDeserializer(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 ListDeserializer implementation public partial class ListDeserializer { #region Constructors @@ -111,7 +202,7 @@ public void Configure(Java.Util.Map arg0, bool arg1) } #endregion - #region ListDeserializer + #region ListDeserializer implementation public partial class ListDeserializer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ListSerializer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ListSerializer.cs index 104e5d7c4..74df7eadf 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ListSerializer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ListSerializer.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,98 @@ namespace Org.Apache.Kafka.Common.Serialization { - #region ListSerializer + #region ListSerializer declaration + /// + /// + /// + public partial class ListSerializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.ListSerializer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ListSerializer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ListSerializer(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 ListSerializer declaration + /// + /// + /// + /// + public partial class ListSerializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase> + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.ListSerializer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ListSerializer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ListSerializer(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 ListSerializer implementation public partial class ListSerializer { #region Constructors @@ -111,7 +202,7 @@ public void Configure(Java.Util.Map arg0, bool arg1) } #endregion - #region ListSerializer + #region ListSerializer implementation public partial class ListSerializer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/LongDeserializer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/LongDeserializer.cs index 7b99af182..565895f7f 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/LongDeserializer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/LongDeserializer.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.Common.Serialization { - #region LongDeserializer + #region LongDeserializer declaration + /// + /// + /// + public partial class LongDeserializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.LongDeserializer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public LongDeserializer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public LongDeserializer(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 LongDeserializer implementation public partial class LongDeserializer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/LongSerializer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/LongSerializer.cs index fec525e51..aa7eea1f2 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/LongSerializer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/LongSerializer.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.Common.Serialization { - #region LongSerializer + #region LongSerializer declaration + /// + /// + /// + public partial class LongSerializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.LongSerializer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public LongSerializer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public LongSerializer(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 LongSerializer implementation public partial class LongSerializer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/Serde.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/Serde.cs index 307ad5fb5..bb4b3a572 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/Serde.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/Serde.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,142 @@ namespace Org.Apache.Kafka.Common.Serialization { - #region Serde + #region Serde declaration + /// + /// + /// + public partial class Serde : MASES.JCOBridge.C2JBridge.JVMBridgeListener + { + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Serde() { InitializeHandlers(); } + + const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.common.serialization.Serde"; + private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = 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; + + + // TODO: complete the class + + } + #endregion + + #region SerdeDirect declaration + /// + /// Direct override of or its generic type if there is one + /// + public partial class SerdeDirect : Serde + { + /// + /// + /// + public override bool AutoInit => false; + + /// + protected override void InitializeHandlers() { } + + const string _bridgeClassName = "org.apache.kafka.common.serialization.Serde"; + 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; + } + #endregion + + #region Serde declaration + /// + /// + /// + /// + public partial class Serde : MASES.JCOBridge.C2JBridge.JVMBridgeListener + { + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Serde() { InitializeHandlers(); } + + const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.common.serialization.Serde"; + private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = 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; + + + // TODO: complete the class + + } + #endregion + + #region SerdeDirect declaration + /// + /// Direct override of or its generic type if there is one + /// + public partial class SerdeDirect : Serde + { + /// + /// + /// + public override bool AutoInit => false; + + /// + protected override void InitializeHandlers() { } + + const string _bridgeClassName = "org.apache.kafka.common.serialization.Serde"; + 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; + } + #endregion + + #region Serde implementation public partial class Serde { #region Constructors @@ -50,10 +185,10 @@ public partial class Serde /// protected virtual void InitializeHandlers() { - AddEventHandler("deserializer", new global::System.EventHandler>(DeserializerEventHandler)); - AddEventHandler("serializer", new global::System.EventHandler>(SerializerEventHandler)); - AddEventHandler("close", new global::System.EventHandler>(CloseEventHandler)); - AddEventHandler("configure", new global::System.EventHandler>>(ConfigureEventHandler)); + AddEventHandler("deserializer", new global::System.EventHandler>>(DeserializerEventHandler)); + AddEventHandler("serializer", new global::System.EventHandler>>(SerializerEventHandler)); + AddEventHandler("close", new global::System.EventHandler>>(CloseEventHandler)); + AddEventHandler("configure", new global::System.EventHandler>>(ConfigureEventHandler)); } @@ -63,11 +198,13 @@ protected virtual void InitializeHandlers() /// If has a value it takes precedence over corresponding class method public global::System.Func OnDeserializer { get; set; } = null; - void DeserializerEventHandler(object sender, CLRListenerEventArgs data) + bool hasOverrideDeserializer = true; + void DeserializerEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideDeserializer = true; var methodToExecute = (OnDeserializer != null) ? OnDeserializer : Deserializer; var executionResult = methodToExecute.Invoke(); - data.SetReturnValue(executionResult); + data.EventData.TypedEventData.SetReturnData(hasOverrideDeserializer, executionResult); } /// @@ -76,7 +213,7 @@ void DeserializerEventHandler(object sender, CLRListenerEventArgs /// public virtual Org.Apache.Kafka.Common.Serialization.Deserializer Deserializer() { - return default; + hasOverrideDeserializer = false; return default; } /// @@ -85,11 +222,13 @@ public virtual Org.Apache.Kafka.Common.Serialization.Deserializer Deserializer() /// If has a value it takes precedence over corresponding class method public global::System.Func OnSerializer { get; set; } = null; - void SerializerEventHandler(object sender, CLRListenerEventArgs data) + bool hasOverrideSerializer = true; + void SerializerEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideSerializer = true; var methodToExecute = (OnSerializer != null) ? OnSerializer : Serializer; var executionResult = methodToExecute.Invoke(); - data.SetReturnValue(executionResult); + data.EventData.TypedEventData.SetReturnData(hasOverrideSerializer, executionResult); } /// @@ -98,7 +237,7 @@ void SerializerEventHandler(object sender, CLRListenerEventArgs da /// public virtual Org.Apache.Kafka.Common.Serialization.Serializer Serializer() { - return default; + hasOverrideSerializer = false; return default; } /// /// @@ -115,10 +254,13 @@ public void CloseDefault() /// If has a value it takes precedence over corresponding class method public global::System.Action OnClose { get; set; } = null; - void CloseEventHandler(object sender, CLRListenerEventArgs data) + bool hasOverrideClose = true; + void CloseEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideClose = true; var methodToExecute = (OnClose != null) ? OnClose : Close; methodToExecute.Invoke(); + data.EventData.TypedEventData.HasOverride = hasOverrideClose; } /// @@ -127,7 +269,7 @@ void CloseEventHandler(object sender, CLRListenerEventArgs data) /// The method invokes the default implementation in the JVM interface using ; override the method to implement a different behavior public virtual void Close() { - CloseDefault(); + hasOverrideClose = false; } /// /// @@ -146,10 +288,13 @@ public void ConfigureDefault(Java.Util.Map arg0, bool arg1) /// If has a value it takes precedence over corresponding class method public global::System.Action OnConfigure { get; set; } = null; - void ConfigureEventHandler(object sender, CLRListenerEventArgs> data) + bool hasOverrideConfigure = true; + void ConfigureEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideConfigure = true; var methodToExecute = (OnConfigure != null) ? OnConfigure : Configure; - methodToExecute.Invoke(data.EventData.TypedEventData, data.EventData.GetAt(0)); + methodToExecute.Invoke(data.EventData.GetAt(0), data.EventData.GetAt(1)); + data.EventData.TypedEventData.HasOverride = hasOverrideConfigure; } /// @@ -160,7 +305,7 @@ void ConfigureEventHandler(object sender, CLRListenerEventArgsThe method invokes the default implementation in the JVM interface using ; override the method to implement a different behavior public virtual void Configure(Java.Util.Map arg0, bool arg1) { - ConfigureDefault(arg0, arg1); + hasOverrideConfigure = false; } #endregion @@ -173,7 +318,7 @@ public virtual void Configure(Java.Util.Map arg0, bool arg1) } #endregion - #region SerdeDirect + #region SerdeDirect implementation public partial class SerdeDirect { #region Constructors @@ -254,7 +399,7 @@ public partial interface ISerde } #endregion - #region Serde + #region Serde implementation public partial class Serde : Org.Apache.Kafka.Common.Serialization.ISerde { #region Constructors @@ -279,10 +424,10 @@ public partial class Serde : Org.Apache.Kafka.Common.Serialization.ISerde /// protected virtual void InitializeHandlers() { - AddEventHandler("deserializer", new global::System.EventHandler>(DeserializerEventHandler)); - AddEventHandler("serializer", new global::System.EventHandler>(SerializerEventHandler)); - AddEventHandler("close", new global::System.EventHandler>(CloseEventHandler)); - AddEventHandler("configure", new global::System.EventHandler>>>(ConfigureEventHandler)); + AddEventHandler("deserializer", new global::System.EventHandler>>(DeserializerEventHandler)); + AddEventHandler("serializer", new global::System.EventHandler>>(SerializerEventHandler)); + AddEventHandler("close", new global::System.EventHandler>>(CloseEventHandler)); + AddEventHandler("configure", new global::System.EventHandler>>(ConfigureEventHandler)); } @@ -292,11 +437,13 @@ protected virtual void InitializeHandlers() /// If has a value it takes precedence over corresponding class method public global::System.Func> OnDeserializer { get; set; } = null; - void DeserializerEventHandler(object sender, CLRListenerEventArgs data) + bool hasOverrideDeserializer = true; + void DeserializerEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideDeserializer = true; var methodToExecute = (OnDeserializer != null) ? OnDeserializer : Deserializer; var executionResult = methodToExecute.Invoke(); - data.SetReturnValue(executionResult); + data.EventData.TypedEventData.SetReturnData(hasOverrideDeserializer, executionResult); } /// @@ -305,7 +452,7 @@ void DeserializerEventHandler(object sender, CLRListenerEventArgs /// public virtual Org.Apache.Kafka.Common.Serialization.Deserializer Deserializer() { - return default; + hasOverrideDeserializer = false; return default; } /// @@ -314,11 +461,13 @@ public virtual Org.Apache.Kafka.Common.Serialization.Deserializer Deserialize /// If has a value it takes precedence over corresponding class method public global::System.Func> OnSerializer { get; set; } = null; - void SerializerEventHandler(object sender, CLRListenerEventArgs data) + bool hasOverrideSerializer = true; + void SerializerEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideSerializer = true; var methodToExecute = (OnSerializer != null) ? OnSerializer : Serializer; var executionResult = methodToExecute.Invoke(); - data.SetReturnValue(executionResult); + data.EventData.TypedEventData.SetReturnData(hasOverrideSerializer, executionResult); } /// @@ -327,7 +476,7 @@ void SerializerEventHandler(object sender, CLRListenerEventArgs da /// public virtual Org.Apache.Kafka.Common.Serialization.Serializer Serializer() { - return default; + hasOverrideSerializer = false; return default; } /// /// @@ -344,10 +493,13 @@ public void CloseDefault() /// If has a value it takes precedence over corresponding class method public global::System.Action OnClose { get; set; } = null; - void CloseEventHandler(object sender, CLRListenerEventArgs data) + bool hasOverrideClose = true; + void CloseEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideClose = true; var methodToExecute = (OnClose != null) ? OnClose : Close; methodToExecute.Invoke(); + data.EventData.TypedEventData.HasOverride = hasOverrideClose; } /// @@ -356,7 +508,7 @@ void CloseEventHandler(object sender, CLRListenerEventArgs data) /// The method invokes the default implementation in the JVM interface using ; override the method to implement a different behavior public virtual void Close() { - CloseDefault(); + hasOverrideClose = false; } /// /// @@ -375,10 +527,13 @@ public void ConfigureDefault(Java.Util.Map arg0, bool /// If has a value it takes precedence over corresponding class method public global::System.Action, bool> OnConfigure { get; set; } = null; - void ConfigureEventHandler(object sender, CLRListenerEventArgs>> data) + bool hasOverrideConfigure = true; + void ConfigureEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideConfigure = true; var methodToExecute = (OnConfigure != null) ? OnConfigure : Configure; - methodToExecute.Invoke(data.EventData.TypedEventData, data.EventData.GetAt(0)); + methodToExecute.Invoke(data.EventData.GetAt>(0), data.EventData.GetAt(1)); + data.EventData.TypedEventData.HasOverride = hasOverrideConfigure; } /// @@ -389,7 +544,7 @@ void ConfigureEventHandler(object sender, CLRListenerEventArgsThe method invokes the default implementation in the JVM interface using ; override the method to implement a different behavior public virtual void Configure(Java.Util.Map arg0, bool arg1) { - ConfigureDefault(arg0, arg1); + hasOverrideConfigure = false; } #endregion @@ -402,7 +557,7 @@ public virtual void Configure(Java.Util.Map arg0, bool } #endregion - #region SerdeDirect + #region SerdeDirect implementation public partial class SerdeDirect : Org.Apache.Kafka.Common.Serialization.ISerde { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/Serdes.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/Serdes.cs index 2b1d77dba..ef1b0c016 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/Serdes.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/Serdes.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,774 @@ namespace Org.Apache.Kafka.Common.Serialization { - #region Serdes + #region Serdes declaration + /// + /// + /// + public partial class Serdes : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Serdes() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public Serdes(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 BooleanSerde declaration + /// + /// + /// + public partial class BooleanSerde : Org.Apache.Kafka.Common.Serialization.Serdes.WrapperSerde + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$BooleanSerde"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public BooleanSerde() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public BooleanSerde(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 ByteArraySerde declaration + /// + /// + /// + public partial class ByteArraySerde : Org.Apache.Kafka.Common.Serialization.Serdes.WrapperSerde + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$ByteArraySerde"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ByteArraySerde() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ByteArraySerde(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 ByteBufferSerde declaration + /// + /// + /// + public partial class ByteBufferSerde : Org.Apache.Kafka.Common.Serialization.Serdes.WrapperSerde + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$ByteBufferSerde"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ByteBufferSerde() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ByteBufferSerde(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 BytesSerde declaration + /// + /// + /// + public partial class BytesSerde : Org.Apache.Kafka.Common.Serialization.Serdes.WrapperSerde + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$BytesSerde"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public BytesSerde() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public BytesSerde(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 DoubleSerde declaration + /// + /// + /// + public partial class DoubleSerde : Org.Apache.Kafka.Common.Serialization.Serdes.WrapperSerde + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$DoubleSerde"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public DoubleSerde() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public DoubleSerde(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 FloatSerde declaration + /// + /// + /// + public partial class FloatSerde : Org.Apache.Kafka.Common.Serialization.Serdes.WrapperSerde + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$FloatSerde"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public FloatSerde() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public FloatSerde(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 IntegerSerde declaration + /// + /// + /// + public partial class IntegerSerde : Org.Apache.Kafka.Common.Serialization.Serdes.WrapperSerde + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$IntegerSerde"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public IntegerSerde() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public IntegerSerde(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 ListSerde declaration + /// + /// + /// + public partial class ListSerde : Org.Apache.Kafka.Common.Serialization.Serdes.WrapperSerde + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$ListSerde"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ListSerde() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ListSerde(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 ListSerde declaration + /// + /// + /// + /// + public partial class ListSerde : Org.Apache.Kafka.Common.Serialization.Serdes.WrapperSerde> + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$ListSerde"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ListSerde() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ListSerde(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 LongSerde declaration + /// + /// + /// + public partial class LongSerde : Org.Apache.Kafka.Common.Serialization.Serdes.WrapperSerde + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$LongSerde"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public LongSerde() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public LongSerde(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 ShortSerde declaration + /// + /// + /// + public partial class ShortSerde : Org.Apache.Kafka.Common.Serialization.Serdes.WrapperSerde + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$ShortSerde"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ShortSerde() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ShortSerde(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 StringSerde declaration + /// + /// + /// + public partial class StringSerde : Org.Apache.Kafka.Common.Serialization.Serdes.WrapperSerde + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$StringSerde"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public StringSerde() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public StringSerde(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 UUIDSerde declaration + /// + /// + /// + public partial class UUIDSerde : Org.Apache.Kafka.Common.Serialization.Serdes.WrapperSerde + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$UUIDSerde"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public UUIDSerde() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public UUIDSerde(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 VoidSerde declaration + /// + /// + /// + public partial class VoidSerde : Org.Apache.Kafka.Common.Serialization.Serdes.WrapperSerde + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$VoidSerde"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public VoidSerde() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public VoidSerde(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 WrapperSerde declaration + /// + /// + /// + public partial class WrapperSerde : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$WrapperSerde"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public WrapperSerde() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public WrapperSerde(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 WrapperSerde declaration + /// + /// + /// + /// + public partial class WrapperSerde : MASES.JCOBridge.C2JBridge.JVMBridgeBase> + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.Serdes$WrapperSerde"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public WrapperSerde() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public WrapperSerde(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 Serdes implementation public partial class Serdes { #region Constructors @@ -305,7 +1072,7 @@ public static Org.Apache.Kafka.Common.Serialization.Serde ByteArrayDirec #endregion #region Nested classes - #region BooleanSerde + #region BooleanSerde implementation public partial class BooleanSerde { #region Constructors @@ -336,7 +1103,7 @@ public partial class BooleanSerde } #endregion - #region ByteArraySerde + #region ByteArraySerde implementation public partial class ByteArraySerde { #region Constructors @@ -367,7 +1134,7 @@ public partial class ByteArraySerde } #endregion - #region ByteBufferSerde + #region ByteBufferSerde implementation public partial class ByteBufferSerde { #region Constructors @@ -398,7 +1165,7 @@ public partial class ByteBufferSerde } #endregion - #region BytesSerde + #region BytesSerde implementation public partial class BytesSerde { #region Constructors @@ -429,7 +1196,7 @@ public partial class BytesSerde } #endregion - #region DoubleSerde + #region DoubleSerde implementation public partial class DoubleSerde { #region Constructors @@ -460,7 +1227,7 @@ public partial class DoubleSerde } #endregion - #region FloatSerde + #region FloatSerde implementation public partial class FloatSerde { #region Constructors @@ -491,7 +1258,7 @@ public partial class FloatSerde } #endregion - #region IntegerSerde + #region IntegerSerde implementation public partial class IntegerSerde { #region Constructors @@ -522,7 +1289,7 @@ public partial class IntegerSerde } #endregion - #region ListSerde + #region ListSerde implementation public partial class ListSerde { #region Constructors @@ -562,7 +1329,7 @@ public ListSerde(Java.Lang.Class arg0, Org.Apache.Kafka.Common.Serialization.Ser } #endregion - #region ListSerde + #region ListSerde implementation public partial class ListSerde { #region Constructors @@ -606,7 +1373,7 @@ public ListSerde(Java.Lang.Class arg0, Org.Apache.Kafka.Common.Serialization.Ser } #endregion - #region LongSerde + #region LongSerde implementation public partial class LongSerde { #region Constructors @@ -637,7 +1404,7 @@ public partial class LongSerde } #endregion - #region ShortSerde + #region ShortSerde implementation public partial class ShortSerde { #region Constructors @@ -668,7 +1435,7 @@ public partial class ShortSerde } #endregion - #region StringSerde + #region StringSerde implementation public partial class StringSerde { #region Constructors @@ -699,7 +1466,7 @@ public partial class StringSerde } #endregion - #region UUIDSerde + #region UUIDSerde implementation public partial class UUIDSerde { #region Constructors @@ -730,7 +1497,7 @@ public partial class UUIDSerde } #endregion - #region VoidSerde + #region VoidSerde implementation public partial class VoidSerde { #region Constructors @@ -761,7 +1528,7 @@ public partial class VoidSerde } #endregion - #region WrapperSerde + #region WrapperSerde implementation public partial class WrapperSerde { #region Constructors @@ -853,7 +1620,7 @@ public void Configure(Java.Util.Map arg0, bool arg1) } #endregion - #region WrapperSerde + #region WrapperSerde implementation public partial class WrapperSerde { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/Serializer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/Serializer.cs index 7dc239b13..54b00b889 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/Serializer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/Serializer.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,142 @@ namespace Org.Apache.Kafka.Common.Serialization { - #region Serializer + #region Serializer declaration + /// + /// + /// + public partial class Serializer : MASES.JCOBridge.C2JBridge.JVMBridgeListener + { + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Serializer() { InitializeHandlers(); } + + const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.common.serialization.Serializer"; + private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = 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; + + + // TODO: complete the class + + } + #endregion + + #region SerializerDirect declaration + /// + /// Direct override of or its generic type if there is one + /// + public partial class SerializerDirect : Serializer + { + /// + /// + /// + public override bool AutoInit => false; + + /// + protected override void InitializeHandlers() { } + + const string _bridgeClassName = "org.apache.kafka.common.serialization.Serializer"; + 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; + } + #endregion + + #region Serializer declaration + /// + /// + /// + /// + public partial class Serializer : MASES.JCOBridge.C2JBridge.JVMBridgeListener + { + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public Serializer() { InitializeHandlers(); } + + const string _bridgeClassName = "org.mases.knet.generated.org.apache.kafka.common.serialization.Serializer"; + private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = 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; + + + // TODO: complete the class + + } + #endregion + + #region SerializerDirect declaration + /// + /// Direct override of or its generic type if there is one + /// + public partial class SerializerDirect : Serializer + { + /// + /// + /// + public override bool AutoInit => false; + + /// + protected override void InitializeHandlers() { } + + const string _bridgeClassName = "org.apache.kafka.common.serialization.Serializer"; + 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; + } + #endregion + + #region Serializer implementation public partial class Serializer { #region Constructors @@ -50,10 +185,10 @@ public partial class Serializer /// protected virtual void InitializeHandlers() { - AddEventHandler("serialize", new global::System.EventHandler>>(SerializeEventHandler)); - AddEventHandler("serialize3", new global::System.EventHandler>>(Serialize3EventHandler)); - AddEventHandler("close", new global::System.EventHandler>(CloseEventHandler)); - AddEventHandler("configure", new global::System.EventHandler>>(ConfigureEventHandler)); + AddEventHandler("serialize", new global::System.EventHandler>>(SerializeEventHandler)); + AddEventHandler("serialize3", new global::System.EventHandler>>(Serialize3EventHandler)); + AddEventHandler("close", new global::System.EventHandler>>(CloseEventHandler)); + AddEventHandler("configure", new global::System.EventHandler>>(ConfigureEventHandler)); } @@ -63,11 +198,13 @@ protected virtual void InitializeHandlers() /// If has a value it takes precedence over corresponding class method public global::System.Func OnSerialize { get; set; } = null; - void SerializeEventHandler(object sender, CLRListenerEventArgs> data) + bool hasOverrideSerialize = true; + void SerializeEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideSerialize = true; var methodToExecute = (OnSerialize != null) ? OnSerialize : Serialize; - var executionResult = methodToExecute.Invoke(data.EventData.TypedEventData, data.EventData.GetAt(0)); - data.SetReturnValue(executionResult); + var executionResult = methodToExecute.Invoke(data.EventData.GetAt(0), data.EventData.GetAt(1)); + data.EventData.TypedEventData.SetReturnData(hasOverrideSerialize, executionResult); } /// @@ -78,7 +215,7 @@ void SerializeEventHandler(object sender, CLRListenerEventArgs public virtual byte[] Serialize(Java.Lang.String arg0, object arg1) { - return default; + hasOverrideSerialize = false; return default; } /// /// @@ -99,11 +236,13 @@ public byte[] SerializeDefault(Java.Lang.String arg0, Org.Apache.Kafka.Common.He /// If has a value it takes precedence over corresponding class method public global::System.Func OnSerialize3 { get; set; } = null; - void Serialize3EventHandler(object sender, CLRListenerEventArgs> data) + bool hasOverrideSerialize3 = true; + void Serialize3EventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideSerialize3 = true; var methodToExecute = (OnSerialize3 != null) ? OnSerialize3 : Serialize; - var executionResult = methodToExecute.Invoke(data.EventData.TypedEventData, data.EventData.GetAt(0), data.EventData.GetAt(1)); - data.SetReturnValue(executionResult); + var executionResult = methodToExecute.Invoke(data.EventData.GetAt(0), data.EventData.GetAt(1), data.EventData.GetAt(2)); + data.EventData.TypedEventData.SetReturnData(hasOverrideSerialize3, executionResult); } /// @@ -116,7 +255,7 @@ void Serialize3EventHandler(object sender, CLRListenerEventArgsThe method invokes the default implementation in the JVM interface using ; override the method to implement a different behavior public virtual byte[] Serialize(Java.Lang.String arg0, Org.Apache.Kafka.Common.Header.Headers arg1, object arg2) { - return SerializeDefault(arg0, arg1, arg2); + hasOverrideSerialize3 = false; return default; } /// /// @@ -133,10 +272,13 @@ public void CloseDefault() /// If has a value it takes precedence over corresponding class method public global::System.Action OnClose { get; set; } = null; - void CloseEventHandler(object sender, CLRListenerEventArgs data) + bool hasOverrideClose = true; + void CloseEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideClose = true; var methodToExecute = (OnClose != null) ? OnClose : Close; methodToExecute.Invoke(); + data.EventData.TypedEventData.HasOverride = hasOverrideClose; } /// @@ -145,7 +287,7 @@ void CloseEventHandler(object sender, CLRListenerEventArgs data) /// The method invokes the default implementation in the JVM interface using ; override the method to implement a different behavior public virtual void Close() { - CloseDefault(); + hasOverrideClose = false; } /// /// @@ -164,10 +306,13 @@ public void ConfigureDefault(Java.Util.Map arg0, bool arg1) /// If has a value it takes precedence over corresponding class method public global::System.Action OnConfigure { get; set; } = null; - void ConfigureEventHandler(object sender, CLRListenerEventArgs> data) + bool hasOverrideConfigure = true; + void ConfigureEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideConfigure = true; var methodToExecute = (OnConfigure != null) ? OnConfigure : Configure; - methodToExecute.Invoke(data.EventData.TypedEventData, data.EventData.GetAt(0)); + methodToExecute.Invoke(data.EventData.GetAt(0), data.EventData.GetAt(1)); + data.EventData.TypedEventData.HasOverride = hasOverrideConfigure; } /// @@ -178,7 +323,7 @@ void ConfigureEventHandler(object sender, CLRListenerEventArgsThe method invokes the default implementation in the JVM interface using ; override the method to implement a different behavior public virtual void Configure(Java.Util.Map arg0, bool arg1) { - ConfigureDefault(arg0, arg1); + hasOverrideConfigure = false; } #endregion @@ -191,7 +336,7 @@ public virtual void Configure(Java.Util.Map arg0, bool arg1) } #endregion - #region SerializerDirect + #region SerializerDirect implementation public partial class SerializerDirect { #region Constructors @@ -277,7 +422,7 @@ public partial interface ISerializer } #endregion - #region Serializer + #region Serializer implementation public partial class Serializer : Org.Apache.Kafka.Common.Serialization.ISerializer { #region Constructors @@ -302,10 +447,10 @@ public partial class Serializer : Org.Apache.Kafka.Common.Serialization.ISeri /// protected virtual void InitializeHandlers() { - AddEventHandler("serialize", new global::System.EventHandler>>(SerializeEventHandler)); - AddEventHandler("serialize3", new global::System.EventHandler>>(Serialize3EventHandler)); - AddEventHandler("close", new global::System.EventHandler>(CloseEventHandler)); - AddEventHandler("configure", new global::System.EventHandler>>>(ConfigureEventHandler)); + AddEventHandler("serialize", new global::System.EventHandler>>(SerializeEventHandler)); + AddEventHandler("serialize3", new global::System.EventHandler>>(Serialize3EventHandler)); + AddEventHandler("close", new global::System.EventHandler>>(CloseEventHandler)); + AddEventHandler("configure", new global::System.EventHandler>>(ConfigureEventHandler)); } @@ -315,11 +460,13 @@ protected virtual void InitializeHandlers() /// If has a value it takes precedence over corresponding class method public global::System.Func OnSerialize { get; set; } = null; - void SerializeEventHandler(object sender, CLRListenerEventArgs> data) + bool hasOverrideSerialize = true; + void SerializeEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideSerialize = true; var methodToExecute = (OnSerialize != null) ? OnSerialize : Serialize; - var executionResult = methodToExecute.Invoke(data.EventData.TypedEventData, data.EventData.GetAt(0)); - data.SetReturnValue(executionResult); + var executionResult = methodToExecute.Invoke(data.EventData.GetAt(0), data.EventData.GetAt(1)); + data.EventData.TypedEventData.SetReturnData(hasOverrideSerialize, executionResult); } /// @@ -330,7 +477,7 @@ void SerializeEventHandler(object sender, CLRListenerEventArgs public virtual byte[] Serialize(Java.Lang.String arg0, T arg1) { - return default; + hasOverrideSerialize = false; return default; } /// /// @@ -351,11 +498,13 @@ public byte[] SerializeDefault(Java.Lang.String arg0, Org.Apache.Kafka.Common.He /// If has a value it takes precedence over corresponding class method public global::System.Func OnSerialize3 { get; set; } = null; - void Serialize3EventHandler(object sender, CLRListenerEventArgs> data) + bool hasOverrideSerialize3 = true; + void Serialize3EventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideSerialize3 = true; var methodToExecute = (OnSerialize3 != null) ? OnSerialize3 : Serialize; - var executionResult = methodToExecute.Invoke(data.EventData.TypedEventData, data.EventData.GetAt(0), data.EventData.GetAt(1)); - data.SetReturnValue(executionResult); + var executionResult = methodToExecute.Invoke(data.EventData.GetAt(0), data.EventData.GetAt(1), data.EventData.GetAt(2)); + data.EventData.TypedEventData.SetReturnData(hasOverrideSerialize3, executionResult); } /// @@ -368,7 +517,7 @@ void Serialize3EventHandler(object sender, CLRListenerEventArgsThe method invokes the default implementation in the JVM interface using ; override the method to implement a different behavior public virtual byte[] Serialize(Java.Lang.String arg0, Org.Apache.Kafka.Common.Header.Headers arg1, T arg2) { - return SerializeDefault(arg0, arg1, arg2); + hasOverrideSerialize3 = false; return default; } /// /// @@ -385,10 +534,13 @@ public void CloseDefault() /// If has a value it takes precedence over corresponding class method public global::System.Action OnClose { get; set; } = null; - void CloseEventHandler(object sender, CLRListenerEventArgs data) + bool hasOverrideClose = true; + void CloseEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideClose = true; var methodToExecute = (OnClose != null) ? OnClose : Close; methodToExecute.Invoke(); + data.EventData.TypedEventData.HasOverride = hasOverrideClose; } /// @@ -397,7 +549,7 @@ void CloseEventHandler(object sender, CLRListenerEventArgs data) /// The method invokes the default implementation in the JVM interface using ; override the method to implement a different behavior public virtual void Close() { - CloseDefault(); + hasOverrideClose = false; } /// /// @@ -416,10 +568,13 @@ public void ConfigureDefault(Java.Util.Map arg0, bool /// If has a value it takes precedence over corresponding class method public global::System.Action, bool> OnConfigure { get; set; } = null; - void ConfigureEventHandler(object sender, CLRListenerEventArgs>> data) + bool hasOverrideConfigure = true; + void ConfigureEventHandler(object sender, CLRListenerEventArgs> data) { + hasOverrideConfigure = true; var methodToExecute = (OnConfigure != null) ? OnConfigure : Configure; - methodToExecute.Invoke(data.EventData.TypedEventData, data.EventData.GetAt(0)); + methodToExecute.Invoke(data.EventData.GetAt>(0), data.EventData.GetAt(1)); + data.EventData.TypedEventData.HasOverride = hasOverrideConfigure; } /// @@ -430,7 +585,7 @@ void ConfigureEventHandler(object sender, CLRListenerEventArgsThe method invokes the default implementation in the JVM interface using ; override the method to implement a different behavior public virtual void Configure(Java.Util.Map arg0, bool arg1) { - ConfigureDefault(arg0, arg1); + hasOverrideConfigure = false; } #endregion @@ -443,7 +598,7 @@ public virtual void Configure(Java.Util.Map arg0, bool } #endregion - #region SerializerDirect + #region SerializerDirect implementation public partial class SerializerDirect : Org.Apache.Kafka.Common.Serialization.ISerializer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ShortDeserializer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ShortDeserializer.cs index c4a8564df..bc5377211 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ShortDeserializer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ShortDeserializer.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.Common.Serialization { - #region ShortDeserializer + #region ShortDeserializer declaration + /// + /// + /// + public partial class ShortDeserializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.ShortDeserializer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ShortDeserializer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ShortDeserializer(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 ShortDeserializer implementation public partial class ShortDeserializer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ShortSerializer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ShortSerializer.cs index 32d730d43..dde77a5b8 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ShortSerializer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/ShortSerializer.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.Common.Serialization { - #region ShortSerializer + #region ShortSerializer declaration + /// + /// + /// + public partial class ShortSerializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.ShortSerializer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public ShortSerializer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public ShortSerializer(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 ShortSerializer implementation public partial class ShortSerializer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/StringDeserializer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/StringDeserializer.cs index e27d71ae5..cbdba9dd3 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/StringDeserializer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/StringDeserializer.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.Common.Serialization { - #region StringDeserializer + #region StringDeserializer declaration + /// + /// + /// + public partial class StringDeserializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.StringDeserializer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public StringDeserializer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public StringDeserializer(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 StringDeserializer implementation public partial class StringDeserializer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/StringSerializer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/StringSerializer.cs index e44c27292..a37403800 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/StringSerializer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/StringSerializer.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.Common.Serialization { - #region StringSerializer + #region StringSerializer declaration + /// + /// + /// + public partial class StringSerializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.StringSerializer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public StringSerializer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public StringSerializer(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 StringSerializer implementation public partial class StringSerializer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/UUIDDeserializer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/UUIDDeserializer.cs index 8d50fdcaf..227eeda43 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/UUIDDeserializer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/UUIDDeserializer.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.Common.Serialization { - #region UUIDDeserializer + #region UUIDDeserializer declaration + /// + /// + /// + public partial class UUIDDeserializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.UUIDDeserializer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public UUIDDeserializer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public UUIDDeserializer(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 UUIDDeserializer implementation public partial class UUIDDeserializer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/UUIDSerializer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/UUIDSerializer.cs index 4feb9481e..f287201b9 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/UUIDSerializer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/UUIDSerializer.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.Common.Serialization { - #region UUIDSerializer + #region UUIDSerializer declaration + /// + /// + /// + public partial class UUIDSerializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.UUIDSerializer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public UUIDSerializer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public UUIDSerializer(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 UUIDSerializer implementation public partial class UUIDSerializer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/VoidDeserializer.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/VoidDeserializer.cs index 8c27d7624..b462371ef 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/VoidDeserializer.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/VoidDeserializer.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.Common.Serialization { - #region VoidDeserializer + #region VoidDeserializer declaration + /// + /// + /// + public partial class VoidDeserializer : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.serialization.VoidDeserializer"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public VoidDeserializer() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public VoidDeserializer(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 VoidDeserializer implementation public partial class VoidDeserializer { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/TopicCollection.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/TopicCollection.cs index b33170ca8..e9ffe5895 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/TopicCollection.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/TopicCollection.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,144 @@ namespace Org.Apache.Kafka.Common { - #region TopicCollection + #region TopicCollection declaration + /// + /// + /// + public partial class TopicCollection : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.TopicCollection"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("TopicCollection 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 TopicCollection() { } + /// + /// 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("TopicCollection 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 TopicCollection(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 + #region TopicIdCollection declaration + /// + /// + /// + public partial class TopicIdCollection : Org.Apache.Kafka.Common.TopicCollection + { + const string _bridgeClassName = "org.apache.kafka.common.TopicCollection$TopicIdCollection"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public TopicIdCollection() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public TopicIdCollection(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 TopicNameCollection declaration + /// + /// + /// + public partial class TopicNameCollection : Org.Apache.Kafka.Common.TopicCollection + { + const string _bridgeClassName = "org.apache.kafka.common.TopicCollection$TopicNameCollection"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public TopicNameCollection() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public TopicNameCollection(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 TopicCollection implementation public partial class TopicCollection { #region Constructors @@ -67,7 +204,7 @@ public static Org.Apache.Kafka.Common.TopicCollection.TopicNameCollection OfTopi #endregion #region Nested classes - #region TopicIdCollection + #region TopicIdCollection implementation public partial class TopicIdCollection { #region Constructors @@ -106,7 +243,7 @@ public partial class TopicIdCollection } #endregion - #region TopicNameCollection + #region TopicNameCollection implementation public partial class TopicNameCollection { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/TopicIdPartition.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/TopicIdPartition.cs index b0118d8e6..097d89ca8 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/TopicIdPartition.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/TopicIdPartition.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.Common { - #region TopicIdPartition + #region TopicIdPartition declaration + /// + /// + /// + public partial class TopicIdPartition : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.TopicIdPartition"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public TopicIdPartition() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public TopicIdPartition(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 TopicIdPartition implementation public partial class TopicIdPartition { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/TopicPartition.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/TopicPartition.cs index 5ff7e095b..1aa3a6ef1 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/TopicPartition.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/TopicPartition.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.Common { - #region TopicPartition + #region TopicPartition declaration + /// + /// + /// + public partial class TopicPartition : Java.Io.Serializable + { + const string _bridgeClassName = "org.apache.kafka.common.TopicPartition"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public TopicPartition() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public TopicPartition(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 TopicPartition implementation public partial class TopicPartition { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/TopicPartitionInfo.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/TopicPartitionInfo.cs index e93668006..6775e2597 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/TopicPartitionInfo.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/TopicPartitionInfo.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.Common { - #region TopicPartitionInfo + #region TopicPartitionInfo declaration + /// + /// + /// + public partial class TopicPartitionInfo : MASES.JCOBridge.C2JBridge.JVMBridgeBase + { + const string _bridgeClassName = "org.apache.kafka.common.TopicPartitionInfo"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public TopicPartitionInfo() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public TopicPartitionInfo(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 TopicPartitionInfo implementation public partial class TopicPartitionInfo { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/TopicPartitionReplica.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/TopicPartitionReplica.cs index 747646586..7d350f1fd 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/TopicPartitionReplica.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/TopicPartitionReplica.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.Common { - #region TopicPartitionReplica + #region TopicPartitionReplica declaration + /// + /// + /// + public partial class TopicPartitionReplica : Java.Io.Serializable + { + const string _bridgeClassName = "org.apache.kafka.common.TopicPartitionReplica"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + public TopicPartitionReplica() { } + /// + /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class + /// + public TopicPartitionReplica(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 TopicPartitionReplica implementation public partial class TopicPartitionReplica { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Utils/AbstractIterator.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Utils/AbstractIterator.cs index 9e6832f64..42c8f299f 100644 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Utils/AbstractIterator.cs +++ b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Utils/AbstractIterator.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.Common.Utils { - #region AbstractIterator + #region AbstractIterator declaration + /// + /// + /// + public partial class AbstractIterator : Java.Util.Iterator + { + const string _bridgeClassName = "org.apache.kafka.common.utils.AbstractIterator"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("AbstractIterator 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 AbstractIterator() { } + /// + /// 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("AbstractIterator 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 AbstractIterator(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 AbstractIterator declaration + /// + /// + /// + /// + public partial class AbstractIterator : Java.Util.Iterator + { + const string _bridgeClassName = "org.apache.kafka.common.utils.AbstractIterator"; + /// + /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge + /// + [global::System.Obsolete("AbstractIterator 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 AbstractIterator() { } + /// + /// 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("AbstractIterator 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 AbstractIterator(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 AbstractIterator implementation public partial class AbstractIterator { #region Constructors @@ -87,7 +182,7 @@ public void Remove() } #endregion - #region AbstractIterator + #region AbstractIterator implementation public partial class AbstractIterator { #region Constructors diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Utils/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Common/Utils/AllPackageClasses.cs deleted file mode 100644 index 8de4aaa51..000000000 --- a/src/net/KNet/Generated/Org/Apache/Kafka/Common/Utils/AllPackageClasses.cs +++ /dev/null @@ -1,2558 +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.Common.Utils -{ - #region AbstractIterator - /// - /// - /// - public partial class AbstractIterator : Java.Util.Iterator - { - const string _bridgeClassName = "org.apache.kafka.common.utils.AbstractIterator"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("AbstractIterator 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 AbstractIterator() { } - /// - /// 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("AbstractIterator 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 AbstractIterator(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 AbstractIterator - /// - /// - /// - /// - public partial class AbstractIterator : Java.Util.Iterator - { - const string _bridgeClassName = "org.apache.kafka.common.utils.AbstractIterator"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("AbstractIterator 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 AbstractIterator() { } - /// - /// 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("AbstractIterator 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 AbstractIterator(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 AppInfoParser - /// - /// - /// - public partial class AppInfoParser : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.utils.AppInfoParser"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public AppInfoParser() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public AppInfoParser(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 AppInfo - /// - /// - /// - public partial class AppInfo : Org.Apache.Kafka.Common.Utils.AppInfoParser.AppInfoMBean - { - const string _bridgeClassName = "org.apache.kafka.common.utils.AppInfoParser$AppInfo"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public AppInfo() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public AppInfo(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 AppInfoMBean - /// - /// - /// - public partial class AppInfoMBean : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.utils.AppInfoParser$AppInfoMBean"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("AppInfoMBean 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 AppInfoMBean() { } - /// - /// 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("AppInfoMBean 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 AppInfoMBean(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 - - - } - #endregion - - #region BufferSupplier - /// - /// - /// - public partial class BufferSupplier : Java.Lang.AutoCloseable - { - const string _bridgeClassName = "org.apache.kafka.common.utils.BufferSupplier"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("BufferSupplier 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 BufferSupplier() { } - /// - /// 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("BufferSupplier 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 BufferSupplier(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 - #region GrowableBufferSupplier - /// - /// - /// - public partial class GrowableBufferSupplier : Org.Apache.Kafka.Common.Utils.BufferSupplier - { - const string _bridgeClassName = "org.apache.kafka.common.utils.BufferSupplier$GrowableBufferSupplier"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public GrowableBufferSupplier() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public GrowableBufferSupplier(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 ByteBufferInputStream - /// - /// - /// - public partial class ByteBufferInputStream : Java.Io.InputStream - { - const string _bridgeClassName = "org.apache.kafka.common.utils.ByteBufferInputStream"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ByteBufferInputStream() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ByteBufferInputStream(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 ByteBufferOutputStream - /// - /// - /// - public partial class ByteBufferOutputStream : Java.Io.OutputStream - { - const string _bridgeClassName = "org.apache.kafka.common.utils.ByteBufferOutputStream"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ByteBufferOutputStream() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ByteBufferOutputStream(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 ByteBufferUnmapper - /// - /// - /// - public partial class ByteBufferUnmapper : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.utils.ByteBufferUnmapper"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ByteBufferUnmapper() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ByteBufferUnmapper(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 Bytes - /// - /// - /// - public partial class Bytes : Java.Lang.Comparable - { - const string _bridgeClassName = "org.apache.kafka.common.utils.Bytes"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Bytes() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Bytes(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 ByteUtils - /// - /// - /// - public partial class ByteUtils : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.utils.ByteUtils"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ByteUtils() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ByteUtils(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 Checksums - /// - /// - /// - public partial class Checksums : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.utils.Checksums"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Checksums() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Checksums(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 ChildFirstClassLoader - /// - /// - /// - public partial class ChildFirstClassLoader : Java.Net.URLClassLoader - { - const string _bridgeClassName = "org.apache.kafka.common.utils.ChildFirstClassLoader"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ChildFirstClassLoader() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ChildFirstClassLoader(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 ChunkedBytesStream - /// - /// - /// - public partial class ChunkedBytesStream : Java.Io.FilterInputStream - { - const string _bridgeClassName = "org.apache.kafka.common.utils.ChunkedBytesStream"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ChunkedBytesStream() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ChunkedBytesStream(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 CircularIterator - /// - /// - /// - public partial class CircularIterator : Java.Util.Iterator - { - const string _bridgeClassName = "org.apache.kafka.common.utils.CircularIterator"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public CircularIterator() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public CircularIterator(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 CircularIterator - /// - /// - /// - /// - public partial class CircularIterator : Java.Util.Iterator - { - const string _bridgeClassName = "org.apache.kafka.common.utils.CircularIterator"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public CircularIterator() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public CircularIterator(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 CloseableIterator - /// - /// - /// - public partial class CloseableIterator : Java.Util.Iterator - { - const string _bridgeClassName = "org.apache.kafka.common.utils.CloseableIterator"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("CloseableIterator 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 CloseableIterator() { } - /// - /// 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("CloseableIterator 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 CloseableIterator(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 CloseableIterator - /// - /// - /// - /// - public partial class CloseableIterator : Java.Util.Iterator - { - const string _bridgeClassName = "org.apache.kafka.common.utils.CloseableIterator"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("CloseableIterator 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 CloseableIterator() { } - /// - /// 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("CloseableIterator 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 CloseableIterator(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 CollectionUtils - /// - /// - /// - public partial class CollectionUtils : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.utils.CollectionUtils"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public CollectionUtils() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public CollectionUtils(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 ConfigUtils - /// - /// - /// - public partial class ConfigUtils : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.utils.ConfigUtils"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ConfigUtils() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ConfigUtils(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 CopyOnWriteMap - /// - /// - /// - public partial class CopyOnWriteMap : Java.Util.Concurrent.ConcurrentMap - { - const string _bridgeClassName = "org.apache.kafka.common.utils.CopyOnWriteMap"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public CopyOnWriteMap() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public CopyOnWriteMap(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 CopyOnWriteMap - /// - /// - /// - /// - /// - public partial class CopyOnWriteMap : Java.Util.Concurrent.ConcurrentMap - { - const string _bridgeClassName = "org.apache.kafka.common.utils.CopyOnWriteMap"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public CopyOnWriteMap() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public CopyOnWriteMap(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 Crc32C - /// - /// - /// - public partial class Crc32C : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.utils.Crc32C"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Crc32C() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Crc32C(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 Exit - /// - /// - /// - public partial class Exit : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.utils.Exit"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Exit() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Exit(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 Procedure - /// - /// - /// - public partial class Procedure : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.utils.Exit$Procedure"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("Procedure 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 Procedure() { } - /// - /// 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("Procedure 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 Procedure(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 ShutdownHookAdder - /// - /// - /// - public partial class ShutdownHookAdder : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.utils.Exit$ShutdownHookAdder"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("ShutdownHookAdder 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 ShutdownHookAdder() { } - /// - /// 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("ShutdownHookAdder 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 ShutdownHookAdder(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 - - - } - #endregion - - #region ExponentialBackoff - /// - /// - /// - public partial class ExponentialBackoff : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.utils.ExponentialBackoff"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ExponentialBackoff() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ExponentialBackoff(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 FixedOrderMap - /// - /// - /// - public partial class FixedOrderMap : Java.Util.LinkedHashMap - { - const string _bridgeClassName = "org.apache.kafka.common.utils.FixedOrderMap"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public FixedOrderMap() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public FixedOrderMap(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 FixedOrderMap - /// - /// - /// - /// - /// - public partial class FixedOrderMap : Java.Util.LinkedHashMap - { - const string _bridgeClassName = "org.apache.kafka.common.utils.FixedOrderMap"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public FixedOrderMap() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public FixedOrderMap(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 FlattenedIterator - /// - /// - /// - public partial class FlattenedIterator : Org.Apache.Kafka.Common.Utils.AbstractIterator - { - const string _bridgeClassName = "org.apache.kafka.common.utils.FlattenedIterator"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public FlattenedIterator() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public FlattenedIterator(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 FlattenedIterator - /// - /// - /// - /// - /// - public partial class FlattenedIterator : Org.Apache.Kafka.Common.Utils.AbstractIterator - { - const string _bridgeClassName = "org.apache.kafka.common.utils.FlattenedIterator"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public FlattenedIterator() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public FlattenedIterator(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 KafkaThread - /// - /// - /// - public partial class KafkaThread : Java.Lang.Thread - { - const string _bridgeClassName = "org.apache.kafka.common.utils.KafkaThread"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public KafkaThread() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public KafkaThread(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 LogContext - /// - /// - /// - public partial class LogContext : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.utils.LogContext"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public LogContext() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public LogContext(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 LoggingSignalHandler - /// - /// - /// - public partial class LoggingSignalHandler : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.utils.LoggingSignalHandler"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public LoggingSignalHandler() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public LoggingSignalHandler(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 MappedIterator - /// - /// - /// - public partial class MappedIterator : Java.Util.Iterator - { - const string _bridgeClassName = "org.apache.kafka.common.utils.MappedIterator"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public MappedIterator() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public MappedIterator(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 MappedIterator - /// - /// - /// - /// - /// - public partial class MappedIterator : Java.Util.Iterator - { - const string _bridgeClassName = "org.apache.kafka.common.utils.MappedIterator"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public MappedIterator() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public MappedIterator(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 OperatingSystem - /// - /// - /// - public partial class OperatingSystem : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.utils.OperatingSystem"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public OperatingSystem() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public OperatingSystem(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 PrimitiveRef - /// - /// - /// - public partial class PrimitiveRef : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.utils.PrimitiveRef"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public PrimitiveRef() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public PrimitiveRef(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 IntRef - /// - /// - /// - public partial class IntRef : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.utils.PrimitiveRef$IntRef"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public IntRef() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public IntRef(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 LongRef - /// - /// - /// - public partial class LongRef : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.utils.PrimitiveRef$LongRef"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public LongRef() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public LongRef(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 ProducerIdAndEpoch - /// - /// - /// - public partial class ProducerIdAndEpoch : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.utils.ProducerIdAndEpoch"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ProducerIdAndEpoch() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ProducerIdAndEpoch(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 PureJavaCrc32C - /// - /// - /// - public partial class PureJavaCrc32C : Java.Util.Zip.Checksum - { - const string _bridgeClassName = "org.apache.kafka.common.utils.PureJavaCrc32C"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public PureJavaCrc32C() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public PureJavaCrc32C(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 Sanitizer - /// - /// - /// - public partial class Sanitizer : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.utils.Sanitizer"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public Sanitizer() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public Sanitizer(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 Scheduler - /// - /// - /// - public partial class Scheduler : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.utils.Scheduler"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("Scheduler 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 Scheduler() { } - /// - /// 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("Scheduler 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 Scheduler(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 SecurityUtils - /// - /// - /// - public partial class SecurityUtils : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.utils.SecurityUtils"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public SecurityUtils() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public SecurityUtils(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 Shell - /// - /// - /// - public partial class Shell : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.utils.Shell"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - [global::System.Obsolete("Shell 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 Shell() { } - /// - /// 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("Shell 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 Shell(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 - #region ExitCodeException - /// - /// - /// - public partial class ExitCodeException : Java.Io.IOException - { - const string _bridgeClassName = "org.apache.kafka.common.utils.Shell$ExitCodeException"; - /// - /// - /// - public override string BridgeClassName => _bridgeClassName; - - // TODO: complete the class - - } - #endregion - - #region ShellCommandExecutor - /// - /// - /// - public partial class ShellCommandExecutor : Org.Apache.Kafka.Common.Utils.Shell - { - const string _bridgeClassName = "org.apache.kafka.common.utils.Shell$ShellCommandExecutor"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ShellCommandExecutor() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ShellCommandExecutor(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 SystemScheduler - /// - /// - /// - public partial class SystemScheduler : Org.Apache.Kafka.Common.Utils.Scheduler - { - const string _bridgeClassName = "org.apache.kafka.common.utils.SystemScheduler"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public SystemScheduler() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public SystemScheduler(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 SystemTime - /// - /// - /// - public partial class SystemTime : Org.Apache.Kafka.Common.Utils.Time - { - const string _bridgeClassName = "org.apache.kafka.common.utils.SystemTime"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public SystemTime() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public SystemTime(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 ThreadUtils - /// - /// - /// - public partial class ThreadUtils : MASES.JCOBridge.C2JBridge.JVMBridgeBase - { - const string _bridgeClassName = "org.apache.kafka.common.utils.ThreadUtils"; - /// - /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge - /// - public ThreadUtils() { } - /// - /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class - /// - public ThreadUtils(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 Time - /// - /// - /// - public partial class Time : MASES.JCOBridge.C2JBridge.JVMBridgeBase