You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by GitBox <gi...@apache.org> on 2022/01/25 12:22:26 UTC

[GitHub] [camel-kafka-connector] nsgeorgi opened a new issue #1330: UNAUTHENTICATED: Credentials require channel with PRIVACY_AND_INTEGRITY security level. Observed security level: NONE

nsgeorgi opened a new issue #1330:
URL: https://github.com/apache/camel-kafka-connector/issues/1330


   Hi guys, Im getting the below exception when my pubsub kafka connector tries to connect to gcp topic. Any ideas?
   
    **```
   ERROR Failure getting messages from PubSub (org.apache.camel.component.google.pubsub.GooglePubsubConsumer:136)
   java.lang.IllegalStateException: Expected the service InnerService [FAILED] to be TERMINATED, but the service has FAILED
   	at com.google.common.util.concurrent.AbstractService.checkCurrentState(AbstractService.java:328)
   	at com.google.common.util.concurrent.AbstractService.awaitTerminated(AbstractService.java:293)
   	at com.google.api.core.AbstractApiService.awaitTerminated(AbstractApiService.java:104)
   	at org.apache.camel.component.google.pubsub.GooglePubsubConsumer$SubscriberWrapper.asynchronousPull(GooglePubsubConsumer.java:134)
   	at org.apache.camel.component.google.pubsub.GooglePubsubConsumer$SubscriberWrapper.run(GooglePubsubConsumer.java:116)
   	at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:511)
   	at java.util.concurrent.FutureTask.run(FutureTask.java:266)
   	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
   	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   	at java.lang.Thread.run(Thread.java:748)
   Caused by: com.google.api.gax.rpc.UnauthenticatedException: com.google.api.gax.rpc.UnauthenticatedException: io.grpc.StatusRuntimeException: UNAUTHENTICATED: Credentials require channel with PRIVACY_AND_INTEGRITY security level. Observed security level: NONE
   	at com.google.api.gax.rpc.ApiExceptionFactory.createException(ApiExceptionFactory.java:73)
   	at com.google.cloud.pubsub.v1.StreamingSubscriberConnection$1.onFailure(StreamingSubscriberConnection.java:282)
   	at com.google.api.core.ApiFutures$1.onFailure(ApiFutures.java:68)
   	at com.google.common.util.concurrent.Futures$4.run(Futures.java:1123)
   	at com.google.common.util.concurrent.MoreExecutors$DirectExecutor.execute(MoreExecutors.java:435)
   	at com.google.common.util.concurrent.AbstractFuture.executeListener(AbstractFuture.java:900)
   	at com.google.common.util.concurrent.AbstractFuture.complete(AbstractFuture.java:811)
   	at com.google.common.util.concurrent.AbstractFuture.setException(AbstractFuture.java:675)
   	at com.google.api.core.AbstractApiFuture$InternalSettableFuture.setException(AbstractApiFuture.java:95)
   	at com.google.api.core.AbstractApiFuture.setException(AbstractApiFuture.java:77)
   	at com.google.api.core.SettableApiFuture.setException(SettableApiFuture.java:52)
   	at com.google.cloud.pubsub.v1.StreamingSubscriberConnection$StreamingPullResponseObserver.onError(StreamingSubscriberConnection.java:209)
   	at com.google.api.gax.tracing.TracedResponseObserver.onError(TracedResponseObserver.java:103)
   	at com.google.api.gax.grpc.ExceptionResponseObserver.onErrorImpl(ExceptionResponseObserver.java:84)
   	at com.google.api.gax.rpc.StateCheckingResponseObserver.onError(StateCheckingResponseObserver.java:86)
   	at com.google.api.gax.grpc.GrpcDirectStreamController$ResponseObserverAdapter.onClose(GrpcDirectStreamController.java:149)
   	at io.grpc.internal.DelayedClientCall$DelayedListener$3.run(DelayedClientCall.java:464)
   	at io.grpc.internal.DelayedClientCall$DelayedListener.delayOrExecute(DelayedClientCall.java:428)
   	at io.grpc.internal.DelayedClientCall$DelayedListener.onClose(DelayedClientCall.java:461)
   	at io.grpc.internal.ClientCallImpl.closeObserver(ClientCallImpl.java:617)
   	at io.grpc.internal.ClientCallImpl.access$300(ClientCallImpl.java:70)
   	at io.grpc.internal.ClientCallImpl$ClientStreamListenerImpl$1StreamClosed.runInternal(ClientCallImpl.java:803)
   	at io.grpc.internal.ClientCallImpl$ClientStreamListenerImpl$1StreamClosed.runInContext(ClientCallImpl.java:782)
   	at io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
   	at io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
   	... 3 more
   Caused by: com.google.api.gax.rpc.UnauthenticatedException: io.grpc.StatusRuntimeException: UNAUTHENTICATED: Credentials require channel with PRIVACY_AND_INTEGRITY security level. Observed security level: NONE
   	at com.google.api.gax.rpc.ApiExceptionFactory.createException(ApiExceptionFactory.java:73)
   	at com.google.api.gax.grpc.GrpcApiExceptionFactory.create(GrpcApiExceptionFactory.java:72)
   	at com.google.api.gax.grpc.GrpcApiExceptionFactory.create(GrpcApiExceptionFactory.java:60)
   	at com.google.api.gax.grpc.ExceptionResponseObserver.onErrorImpl(ExceptionResponseObserver.java:82)
   ```**
   
   
   My config:
   
   **```
   {
       "connector.class": "org.apache.camel.kafkaconnector.googlepubsub.CamelGooglepubsubSourceConnector",
       "type": "source",
       "kafka.topic": "RDH-Updates",
       "key.converter": "org.apache.kafka.connect.storage.StringConverter",
       "value.converter": "org.apache.kafka.connect.storage.StringConverter",
       "value.converter.schemas.enable": false,
       "errors.tolerance": "all",
       "errors.deadletterqueue.topic.name":"RDH-Updates-Failed",
       "errors.deadletterqueue.context.headers.enable": true,
       "errors.log.enable": true,
       "errors.log.include.messages": true,
       "errors.retry.delay.max.ms": 60000,
       "errors.retry.timeout": 300000,
       "camel.source.path.destinationName":"hk_gmo_memberinfo_subscription",
       "camel.source.path.projectId":"***-9594666-refdatahub-dev",
       "camel.component.google-pubsub.endpoint":"googleapis-dev.gcp.cloud.uk.***",
       "camel.component.google-pubsub.serviceAccountKey":"file:/tmp/gcp/rdh-gcp.json",
       "camel.source.endpoint.serviceAccountKey":"file:/tmp/gcp/rdh-gcp.json",
       "kafka.partition.count": 3
     }
   ```**
   
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscribe@camel.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [camel-kafka-connector] oscerd commented on issue #1330: UNAUTHENTICATED: Credentials require channel with PRIVACY_AND_INTEGRITY security level. Observed security level: NONE

Posted by GitBox <gi...@apache.org>.
oscerd commented on issue #1330:
URL: https://github.com/apache/camel-kafka-connector/issues/1330#issuecomment-1026947990


   Is this an issue? You're keeping closing and reopening


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscribe@camel.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [camel-kafka-connector] nsgeorgi closed issue #1330: UNAUTHENTICATED: Credentials require channel with PRIVACY_AND_INTEGRITY security level. Observed security level: NONE

Posted by GitBox <gi...@apache.org>.
nsgeorgi closed issue #1330:
URL: https://github.com/apache/camel-kafka-connector/issues/1330


   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscribe@camel.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [camel-kafka-connector] nsgeorgi closed issue #1330: UNAUTHENTICATED: Credentials require channel with PRIVACY_AND_INTEGRITY security level. Observed security level: NONE

Posted by GitBox <gi...@apache.org>.
nsgeorgi closed issue #1330:
URL: https://github.com/apache/camel-kafka-connector/issues/1330


   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscribe@camel.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [camel-kafka-connector] nsgeorgi closed issue #1330: UNAUTHENTICATED: Credentials require channel with PRIVACY_AND_INTEGRITY security level. Observed security level: NONE

Posted by GitBox <gi...@apache.org>.
nsgeorgi closed issue #1330:
URL: https://github.com/apache/camel-kafka-connector/issues/1330


   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscribe@camel.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [camel-kafka-connector] nsgeorgi closed issue #1330: UNAUTHENTICATED: Credentials require channel with PRIVACY_AND_INTEGRITY security level. Observed security level: NONE

Posted by GitBox <gi...@apache.org>.
nsgeorgi closed issue #1330:
URL: https://github.com/apache/camel-kafka-connector/issues/1330


   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscribe@camel.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [camel-kafka-connector] nsgeorgi commented on issue #1330: UNAUTHENTICATED: Credentials require channel with PRIVACY_AND_INTEGRITY security level. Observed security level: NONE

Posted by GitBox <gi...@apache.org>.
nsgeorgi commented on issue #1330:
URL: https://github.com/apache/camel-kafka-connector/issues/1330#issuecomment-1027817109


   Update: Found the issue, I had to remove  camel.component.google-pubsub.endpoint as serviceAccountKey info already holds the endpoint details. I am closing the ticket


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscribe@camel.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [camel-kafka-connector] nsgeorgi commented on issue #1330: UNAUTHENTICATED: Credentials require channel with PRIVACY_AND_INTEGRITY security level. Observed security level: NONE

Posted by GitBox <gi...@apache.org>.
nsgeorgi commented on issue #1330:
URL: https://github.com/apache/camel-kafka-connector/issues/1330#issuecomment-1026937219


   Camel kafka connector version 0.11


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscribe@camel.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [camel-kafka-connector] nsgeorgi commented on issue #1330: UNAUTHENTICATED: Credentials require channel with PRIVACY_AND_INTEGRITY security level. Observed security level: NONE

Posted by GitBox <gi...@apache.org>.
nsgeorgi commented on issue #1330:
URL: https://github.com/apache/camel-kafka-connector/issues/1330#issuecomment-1026959677


   Hi, yes sorry this is still an issue, I tried to use another lib from google and it was working fine (so the serviceAccountKey is correct). but this credentials error using camel lib still persists. Any idea?


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscribe@camel.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org