Uploaded image for project: 'Apache NiFi'
  1. Apache NiFi
  2. NIFI-10972

PutBigQuery - Invalid project resource name projects/${Project}

    XMLWordPrintableJSON

Details

    • Bug
    • Status: Open
    • Major
    • Resolution: Unresolved
    • 1.19.0, 1.19.1
    • None
    • Core Framework
    • None
    • Debian

    Description

      Processor: PutBigQuery
      Parameter: Project ID
      Value for Project ID: ${Project}
      Problem: attributes are unevaluated
      Error log:

      2022-12-13 10:40:18,955 ERROR [Timer-Driven Process Thread-9] o.a.n.p.gcp.bigquery.PutBigQuery PutBigQuery[id=121711dc-1182-1bfc-7f3d-6fb3bcfc7d0b] Processing halted: yielding [1 sec]
      com.google.api.gax.rpc.InvalidArgumentException: io.grpc.StatusRuntimeException: INVALID_ARGUMENT: Invalid project resource name projects/${Project}; Project id: ${Project}
          at com.google.api.gax.rpc.ApiExceptionFactory.createException(ApiExceptionFactory.java:92)
          at com.google.api.gax.rpc.ApiExceptionFactory.createException(ApiExceptionFactory.java:41)
          at com.google.api.gax.grpc.GrpcApiExceptionFactory.create(GrpcApiExceptionFactory.java:86)
          at com.google.api.gax.grpc.GrpcApiExceptionFactory.create(GrpcApiExceptionFactory.java:66)
          at com.google.api.gax.grpc.GrpcExceptionCallable$ExceptionTransformingFuture.onFailure(GrpcExceptionCallable.java:97)
          at com.google.api.core.ApiFutures$1.onFailure(ApiFutures.java:67)
          at com.google.common.util.concurrent.Futures$CallbackListener.run(Futures.java:1132)
          at com.google.common.util.concurrent.DirectExecutor.execute(DirectExecutor.java:31)
          at com.google.common.util.concurrent.AbstractFuture.executeListener(AbstractFuture.java:1270)
          at com.google.common.util.concurrent.AbstractFuture.complete(AbstractFuture.java:1038)
          at com.google.common.util.concurrent.AbstractFuture.setException(AbstractFuture.java:808)
          at io.grpc.stub.ClientCalls$GrpcFuture.setException(ClientCalls.java:563)
          at io.grpc.stub.ClientCalls$UnaryStreamToFuture.onClose(ClientCalls.java:533)
          at io.grpc.PartialForwardingClientCallListener.onClose(PartialForwardingClientCallListener.java:39)
          at io.grpc.ForwardingClientCallListener.onClose(ForwardingClientCallListener.java:23)
          at io.grpc.ForwardingClientCallListener$SimpleForwardingClientCallListener.onClose(ForwardingClientCallListener.java:40)
          at com.google.api.gax.grpc.ChannelPool$ReleasingClientCall$1.onClose(ChannelPool.java:535)
          at io.grpc.internal.DelayedClientCall$DelayedListener$3.run(DelayedClientCall.java:463)
          at io.grpc.internal.DelayedClientCall$DelayedListener.delayOrExecute(DelayedClientCall.java:427)
          at io.grpc.internal.DelayedClientCall$DelayedListener.onClose(DelayedClientCall.java:460)
          at io.grpc.internal.ClientCallImpl.closeObserver(ClientCallImpl.java:562)
          at io.grpc.internal.ClientCallImpl.access$300(ClientCallImpl.java:70)
          at io.grpc.internal.ClientCallImpl$ClientStreamListenerImpl$1StreamClosed.runInternal(ClientCallImpl.java:743)
          at io.grpc.internal.ClientCallImpl$ClientStreamListenerImpl$1StreamClosed.runInContext(ClientCallImpl.java:722)
          at io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
          at io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
          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:750)
          Suppressed: com.google.api.gax.rpc.AsyncTaskException: Asynchronous task failed
              at com.google.api.gax.rpc.ApiExceptions.callAndTranslateApiException(ApiExceptions.java:57)
              at com.google.api.gax.rpc.UnaryCallable.call(UnaryCallable.java:112)
              at com.google.cloud.bigquery.storage.v1.BigQueryWriteClient.createWriteStream(BigQueryWriteClient.java:231)
              at org.apache.nifi.processors.gcp.bigquery.PutBigQuery.createWriteStream(PutBigQuery.java:380)
              at org.apache.nifi.processors.gcp.bigquery.PutBigQuery.onTrigger(PutBigQuery.java:207)
              at org.apache.nifi.processor.AbstractProcessor.onTrigger(AbstractProcessor.java:27)
              at org.apache.nifi.controller.StandardProcessorNode.onTrigger(StandardProcessorNode.java:1356)
              at org.apache.nifi.controller.tasks.ConnectableTask.invoke(ConnectableTask.java:246)
              at org.apache.nifi.controller.scheduling.AbstractTimeBasedSchedulingAgent.lambda$doScheduleOnce$0(AbstractTimeBasedSchedulingAgent.java:59)
              at org.apache.nifi.engine.FlowEngine$2.run(FlowEngine.java:110)
              at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:511)
              at java.util.concurrent.FutureTask.run(FutureTask.java:266)
              at java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.access$201(ScheduledThreadPoolExecutor.java:180)
              at java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.run(ScheduledThreadPoolExecutor.java:293)
              ... 3 common frames omitted
      Caused by: io.grpc.StatusRuntimeException: INVALID_ARGUMENT: Invalid project resource name projects/${Project}; Project id: ${Project}
          at io.grpc.Status.asRuntimeException(Status.java:535)
          ... 17 common frames omitted
      

      Attachments

        Activity

          People

            Unassigned Unassigned
            hipotures hipotures
            Votes:
            0 Vote for this issue
            Watchers:
            2 Start watching this issue

            Dates

              Created:
              Updated: